A C E G H I J L M N O P R S T U V W 

A

abort() - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
add(Statistics.JobStats) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Used by JobMonitor to add the completed job.
addClusterStatsObservers(StatListener<Statistics.ClusterStats>) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
addJobStats(Statistics.JobStats) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Add a submitted job for monitoring.
addJobStatsListeners(StatListener<Statistics.JobStats>) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 

C

calibrate(ResourceCalculatorPlugin, long) - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.CpuUsageEmulatorCore
Allows the core to calibrate itself.
calibrate(ResourceCalculatorPlugin, long) - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator
This will calibrate the algorithm such that a single invocation of CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator.compute() emulates roughly 1% of the total desired resource usage value.
call() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob
 
canEmulateCompression() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob
 
checkLoadAndGetSlotsToBackfill() - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
We try to use some light-weight mechanism to determine cluster load.
cleanup(Mapper<LongWritable, LongWritable, GridmixKey, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepMapper
 
cleanup(Reducer<GridmixKey, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer
 
compute() - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.CpuUsageEmulatorCore
Performs some computation to use up some CPU.
compute() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator
This will consume some desired level of CPU.
CONF_MAX_JOB_TRACKER_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_MAX_MAPSLOT_SHARE_PER_JOB - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_MAX_REDUCESLOT_SHARE_PER_JOB - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_OVERLOAD_MAPTASK_MAPSLOT_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
CONF_OVERLOAD_REDUCETASK_REDUCESLOT_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
configure(Configuration, ResourceCalculatorPlugin, ResourceUsageMetrics, Progressive) - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageMatcher
Configure the ResourceUsageMatcher to load the configured plugins and initialize them.
CPU_EMULATION_PROGRESS_INTERVAL - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
 
createGridmixJob(Configuration, long, JobStory, Path, UserGroupInformation, int) - Method in enum org.apache.hadoop.mapred.gridmix.JobCreator
Create Gridmix simulated job.
createJobFactory(JobSubmitter, String, Path, Configuration, CountDownLatch, UserResolver) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
createJobMonitor(Statistics, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
createJobStoryProducer(String, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
Create an appropriate JobStoryProducer object for the given trace.
createJobSubmitter(JobMonitor, int, int, FilePool, UserResolver, Statistics) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
createReaderThread() - Method in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
 
createReaderThread() - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepInputFormat
 
CumulativeCpuUsageEmulatorPlugin - Class in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
A ResourceUsageEmulatorPlugin that emulates the cumulative CPU usage by performing certain CPU intensive operations.
CumulativeCpuUsageEmulatorPlugin() - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
 
CumulativeCpuUsageEmulatorPlugin(CumulativeCpuUsageEmulatorPlugin.CpuUsageEmulatorCore) - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
For testing.
CumulativeCpuUsageEmulatorPlugin.CpuUsageEmulatorCore - Interface in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
This is the core CPU usage emulation algorithm.
CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator - Class in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
This is the core engine to emulate the CPU usage.
CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator() - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator

E

EchoUserResolver - Class in org.apache.hadoop.mapred.gridmix
Echos the UGI offered.
EchoUserResolver() - Constructor for class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
emulate() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
 
emulate() - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageEmulatorPlugin
Emulate the resource usage to match the usage target.
emulate() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 
emulatorCore - Variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
 
emulatorCore - Variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 

G

generateJobStats(Job, JobStory) - Static method in class org.apache.hadoop.mapred.gridmix.Statistics
Generates a job stats.
getCurrentUserResolver() - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
getId() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getJobSubmissionPolicy(Configuration) - Static method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
getLength() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getLocations() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getMaxHeapUsageInMB() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 
getNumMaps() - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getPolicy(Configuration, JobCreator) - Static method in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
getPoolSize() - Method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Get the remaining random number pool size.
getProgress() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
 
getProgress() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageMatcher
Returns the average progress.
getProgress() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 
getProgress() - Method in interface org.apache.hadoop.mapred.gridmix.Progressive
 
getReduceDurations(int) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
getSplits(JobContext) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepInputFormat
 
getSummarizer() - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
getTargetUgi(UserGroupInformation) - Method in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
getTargetUgi(UserGroupInformation) - Method in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
getTargetUgi(UserGroupInformation) - Method in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 
getTargetUgi(UserGroupInformation) - Method in interface org.apache.hadoop.mapred.gridmix.UserResolver
Map the given UGI to another per the subclass contract.
getTotalHeapUsageInMB() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 
Gridmix - Class in org.apache.hadoop.mapred.gridmix
Driver class for the Gridmix3 benchmark.
Gridmix() - Constructor for class org.apache.hadoop.mapred.gridmix.Gridmix
 
GRIDMIX_JOB_TYPE - Static variable in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
GRIDMIX_JOBMONITOR_SLEEPTIME_MILLIS - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
The configuration key which determines the duration for which the job-monitor sleeps while polling for job status.
GRIDMIX_JOBMONITOR_SLEEPTIME_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
GRIDMIX_JOBMONITOR_THREADS - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
The configuration key which determines the total number of job-status monitoring threads.
GRIDMIX_JOBMONITOR_THREADS_DEFAULT - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
GRIDMIX_OUT_DIR - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Output (scratch) directory for submitted jobs.
GRIDMIX_QUE_DEP - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
The depth of the queue of job descriptions.
GRIDMIX_SLEEP_INTERVAL - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
Interval at which to report progress, in seconds.
GRIDMIX_SLEEP_MAX_MAP_TIME - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
GRIDMIX_SLEEP_MAX_REDUCE_TIME - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
GRIDMIX_SUB_MUL - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Multiplier to accelerate or decelerate job submission.
GRIDMIX_SUB_THR - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Number of submitting threads at the client and upper bound for in-memory split data.
GRIDMIX_USR_RSV - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Class used to resolve users in the trace to the list of target users on the cluster.

H

HEAP_EMULATION_PROGRESS_INTERVAL - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
The frequency (based on task progress) with which memory-emulation code is run.
HEAP_LOAD_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
Determines the unit increase per call to the core engine's load API.
heapSpace - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator
 

I

initialize(Configuration, ResourceUsageMetrics, ResourceCalculatorPlugin, Progressive) - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin
 
initialize(Configuration, ResourceUsageMetrics, ResourceCalculatorPlugin, Progressive) - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageEmulatorPlugin
Initialize the plugin.
initialize(ResourceCalculatorPlugin, long) - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator
This will initialize the core and check if the core can emulate the desired target on the underlying hardware.
initialize(ResourceCalculatorPlugin, long) - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.HeapUsageEmulatorCore
Initialize the core.
initialize(Configuration, ResourceUsageMetrics, ResourceCalculatorPlugin, Progressive) - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 

J

JobCreator - Enum in org.apache.hadoop.mapred.gridmix
 
join(long) - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Wait until the service completes.

L

load(long) - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator
Increase heap usage by current process by the given amount.
load(long) - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.HeapUsageEmulatorCore
Performs some memory intensive operations to use up some heap.
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.Statistics
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.StressJobFactory
 
LOG - Static variable in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 

M

main(String[]) - Static method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
map(LongWritable, LongWritable, Mapper<LongWritable, LongWritable, GridmixKey, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepMapper
 
matchResourceUsage() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageMatcher
 
MIN_HEAP_FREE_RATIO - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
The minimum buffer reserved for other non-emulation activities.

N

needsTargetUsersList() - Method in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
Indicates whether this user resolver needs a list of target users to be provided.
needsTargetUsersList() - Method in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
Indicates whether this user resolver needs a list of target users to be provided.
needsTargetUsersList() - Method in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
Indicates whether this user resolver needs a list of target users to be provided.
needsTargetUsersList() - Method in interface org.apache.hadoop.mapred.gridmix.UserResolver
Indicates whether this user resolver needs a list of target users to be provided.
next() - Method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Select the next random number.

O

ONE_MB - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 
org.apache.hadoop.mapred.gridmix - package org.apache.hadoop.mapred.gridmix
 
org.apache.hadoop.mapred.gridmix.emulators.resourceusage - package org.apache.hadoop.mapred.gridmix.emulators.resourceusage
 
ORIGINAL_JOB_ID - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Configuration property set in simulated job's configuration whose value is set to the corresponding original job's id.
ORIGINAL_JOB_NAME - Static variable in class org.apache.hadoop.mapred.gridmix.Gridmix
Configuration property set in simulated job's configuration whose value is set to the corresponding original job's name.

P

performUnitComputation() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator
 
printUsage(PrintStream) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 
Progressive - Interface in org.apache.hadoop.mapred.gridmix
Used to track progress of tasks.

R

RandomAlgorithms - Class in org.apache.hadoop.mapred.gridmix
Random algorithms.
RandomAlgorithms() - Constructor for class org.apache.hadoop.mapred.gridmix.RandomAlgorithms
 
RandomAlgorithms.Selector - Class in org.apache.hadoop.mapred.gridmix
Iteratively pick random numbers from pool 0..n-1.
RandomAlgorithms.Selector(int, double, Random) - Constructor for class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Constructor.
readFields(DataInput) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
reset() - Method in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator
Clear references to all the GridMix-allocated special objects so that heap usage is reduced.
reset() - Method in interface org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.HeapUsageEmulatorCore
Reset the resource usage
reset() - Method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms.Selector
Reset the selector for reuse usage.
RESOURCE_USAGE_EMULATION_PLUGINS - Static variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageMatcher
Configuration key to set resource usage emulators.
ResourceUsageEmulatorPlugin - Interface in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
Each resource to be emulated should have a corresponding implementation class that implements ResourceUsageEmulatorPlugin.
ResourceUsageMatcher - Class in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
This is the driver class for managing all the resource usage emulators.
ResourceUsageMatcher() - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.ResourceUsageMatcher
 
returnValue - Variable in class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator
This is to fool the JVM and make it think that we need the value stored in the unit computation i.e CumulativeCpuUsageEmulatorPlugin.DefaultCpuUsageEmulator.compute().
RoundRobinUserResolver - Class in org.apache.hadoop.mapred.gridmix
 
RoundRobinUserResolver() - Constructor for class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
run(String[]) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
 

S

select(int, int, Random) - Static method in class org.apache.hadoop.mapred.gridmix.RandomAlgorithms
Selecting m random integers from 0..n-1.
SerialJobFactory - Class in org.apache.hadoop.mapred.gridmix
 
SerialJobFactory(JobSubmitter, JobStoryProducer, Path, Configuration, CountDownLatch, UserResolver) - Constructor for class org.apache.hadoop.mapred.gridmix.SerialJobFactory
Creating a new instance does not start the thread.
setTargetUsers(URI, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.EchoUserResolver
 
setTargetUsers(URI, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.RoundRobinUserResolver
 
setTargetUsers(URI, Configuration) - Method in class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 
setTargetUsers(URI, Configuration) - Method in interface org.apache.hadoop.mapred.gridmix.UserResolver
Configure the user map given the URI and configuration.
setup(Reducer<GridmixKey, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer
 
shutdown() - Method in class org.apache.hadoop.mapred.gridmix.Statistics
 
SleepJob - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob(Configuration, long, JobStory, Path, UserGroupInformation, int, int, String[]) - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob
 
SleepJob.SleepInputFormat - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepInputFormat() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepInputFormat
 
SleepJob.SleepMapper - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepMapper() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepMapper
 
SleepJob.SleepReducer - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepReducer() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer
 
SleepJob.SleepSplit - Class in org.apache.hadoop.mapred.gridmix
 
SleepJob.SleepSplit() - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
SleepJob.SleepSplit(int, long, long[], int, String[]) - Constructor for class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
SLEEPJOB_MAPTASK_ONLY - Static variable in class org.apache.hadoop.mapred.gridmix.SleepJob
 
SLEEPJOB_RANDOM_LOCATIONS - Static variable in enum org.apache.hadoop.mapred.gridmix.JobCreator
 
start() - Method in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
Start the reader thread, wait for latch if necessary.
start() - Method in class org.apache.hadoop.mapred.gridmix.Statistics
Attempt to start the service.
start() - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
Start the reader thread, wait for latch if necessary.
Statistics - Class in org.apache.hadoop.mapred.gridmix
Component collecting the stats required by other components to make decisions.
Statistics(Configuration, int, CountDownLatch) - Constructor for class org.apache.hadoop.mapred.gridmix.Statistics
 
StressJobFactory - Class in org.apache.hadoop.mapred.gridmix
 
StressJobFactory(JobSubmitter, JobStoryProducer, Path, Configuration, CountDownLatch, UserResolver) - Constructor for class org.apache.hadoop.mapred.gridmix.StressJobFactory
Creating a new instance does not start the thread.
SubmitterUserResolver - Class in org.apache.hadoop.mapred.gridmix
Resolves all UGIs to the submitting user.
SubmitterUserResolver() - Constructor for class org.apache.hadoop.mapred.gridmix.SubmitterUserResolver
 

T

TotalHeapUsageEmulatorPlugin - Class in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
A ResourceUsageEmulatorPlugin that emulates the total heap usage by loading the JVM heap memory.
TotalHeapUsageEmulatorPlugin() - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
 
TotalHeapUsageEmulatorPlugin(TotalHeapUsageEmulatorPlugin.HeapUsageEmulatorCore) - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin
For testing.
TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator - Class in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
This is the core engine to emulate the heap usage.
TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator() - Constructor for class org.apache.hadoop.mapred.gridmix.emulators.resourceusage.TotalHeapUsageEmulatorPlugin.DefaultHeapUsageEmulator
 
TotalHeapUsageEmulatorPlugin.HeapUsageEmulatorCore - Interface in org.apache.hadoop.mapred.gridmix.emulators.resourceusage
Defines the core heap usage emulation algorithm.

U

update(Statistics.JobStats) - Method in class org.apache.hadoop.mapred.gridmix.SerialJobFactory
SERIAL.
update(Statistics.ClusterStats) - Method in class org.apache.hadoop.mapred.gridmix.StressJobFactory
STRESS Once you get the notification from StatsCollector.Collect the clustermetrics.
UserResolver - Interface in org.apache.hadoop.mapred.gridmix
Maps users in the trace to a set of valid target users on the test cluster.

V

valueOf(String) - Static method in enum org.apache.hadoop.mapred.gridmix.JobCreator
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.mapred.gridmix.JobCreator
Returns an array containing the constants of this enum type, in the order they are declared.

W

write(DataOutput) - Method in class org.apache.hadoop.mapred.gridmix.SleepJob.SleepSplit
 
writeDistCacheData(Configuration) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
Write random bytes in the distributed cache files that will be used by all simulated jobs of current gridmix run, if files are to be generated.
writeInputData(long, Path) - Method in class org.apache.hadoop.mapred.gridmix.Gridmix
Write random bytes at the path <inputDir> if needed.
A C E G H I J L M N O P R S T U V W 

Copyright © 2015 Apache Software Foundation. All Rights Reserved.