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

A

activeSubscription - Variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Determines if the actual timed object is going to receive recurring events (through the tick() function).
actualMigration(PhysicalMachine.ResourceAllocation) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
This function is responsible for the actual transfer between the old physical machine and the new one.
actualSwitchOff() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
does the actual switchoff, expected to be run only when there are no VMs running on the PM
add(ResourceConstraints...) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Allows multiple RC objects to be added to this one with variable parameter length This operation is good when the RC objects are held in an array.
add(List<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Allows multiple RC objects to be added to this one with variable parameter length This operation expects a list of RC objects thus it is optimally used when the RC objects are stored in a List anyways.
add(int, QueueingData) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
addAll(int, Collection<? extends QueueingData>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
addFurtherTasks(double[]) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
if there seems to be further operations needed before the particular power state can be achieved then this function should be called.
addSingleToDG(ResourceSpreader) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Allows a single spreader object to be added to the influence group.
addToGroup() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
This function copies the contents of the depGroupExtension list to the array representing the influence group and ensures that all newly added members of the influence group know their group membership.
AggregatedEnergyMeter - Class in hu.mta.sztaki.lpds.cloud.simulator.energy
Allows a group of energy meters to be operated simultaneously.
AggregatedEnergyMeter(List<EnergyMeter>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.AggregatedEnergyMeter
Constructs an aggregated meter with a list of energy meters to operate on top.
allocated - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
The resource set that is virtually offered to the VM that uses this allocation.
allocateResources(ResourceConstraints, boolean, int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Ensures the requested amount of resources are going to be available in the foreseeable future on this physical machine.
AlterableResourceConstraints - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints
Provides an implementation of a resource constraints class that allows in place alterations on its instances
AlterableResourceConstraints(double, double, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
A constructor to define resource constraints with exact amount of resources to start with
AlterableResourceConstraints(double, double, boolean, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
The main constructor to define alterable resource constraints
AlterableResourceConstraints(ResourceConstraints) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Allows to make an arbitrary resourceconstraints object into an alterable one
AlwaysOnMachines - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling
This PM controller ensures that all newly registered PMs are switched on immediately and newer turned off again.
AlwaysOnMachines(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.AlwaysOnMachines
Constructs the scheduler and passes the parent IaaSService to the superclass.
ArrayHandler - Class in hu.mta.sztaki.lpds.cloud.simulator.util
A class to simplify often used arraylist handling operations
ArrayHandler() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.util.ArrayHandler
 
aSecond - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the amount of ticks it takes for a single second to pass in the simulated time
assignProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
Manages the gradual increase of the processing limits for each resource consumption related to this spreader.
availableCapacities - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
This is the publicly disclosed set of those resources that are not having a VM running on them.

B

backPreference - Variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Should two timed events occur on the same time instance this marker allows Timed to determine which ones should be notified first.
behaviorChanged(ResourceSpreader, PowerState) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
on this function the meter receives notifications on power state changes of the particular resource spreader
behaviorChanged(ResourceSpreader, PowerState) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.PowerBehaviorChangeListener
Until subscribed, this function is called every time when a resource spreader switches to a new power state.
bgNetworkLoad - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
The background network load expected to be simulated between the appliance's hosting repository and the PM that hosts the VM while the VM runs its tasks.
buildDepGroup(ResourceSpreader) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Marks all resource spreaders in the currently decomposing influence group that the starting spreader has connections with.
bulkHostRegistration(List<PhysicalMachine>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
This function allows rapid registration of several PMs

C

calcCompletionDistance() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Updates the completion distance field, should be called every time the real limit is updated or when the amount of unprocessed consumption changes.
calcTimeJump(long) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
A simple approach to calculate time advances in the system
cancel() - Method in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
If the call for eventAction() is no longer necessary at the previously specified time then the user can cancel this call to arrive with this function.
cancel() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
if a resource allocation is no longer needed (e.g.
cancel() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
terminates the consumption, deregisters it from its consumer/provider pair and ensures that it can no longer be registered
cancelAllocation(PhysicalMachine.ResourceAllocation) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Terminate a resource allocation through the PM's interfaces
cancelConsumption(ResourceConsumption) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Organizes the coordinated removal of this consumption from the underProcessing list.
cancelEvents() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines.CapacityChangeManager
if the PM gets dropped from the parent IaaSService then we no longer need to control its behavior.
cancelled - Variable in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
Shows if the event in question was cancelled by the user
cancelled - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
shows if the resource consumption has failed to complete for some reason
cancelledListeners - Variable in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
if the notificaiton process is underway, then to be removed listeners are registered here (they will still receive notifications in the current notification round as their de-registration is actually a result of the current notification round)
cancelMonitoring() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
allows the monitoring to be terminated at any arbitrary point of time.
capacityChanged(ResourceConstraints, List<PhysicalMachine>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.IaaSEnergyMeter
manages the changes in size of the infrastructure (e.g.
capacityChanged(ResourceConstraints, List<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.PhysicalMachineEnergyMeter
readjusts the meter (and thus evaluate actual consumption values) if the capacity of the metered physical machine changes
capacityChanged(ResourceConstraints, List<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines.CapacityChangeManager
This function is called when the observed PM has newly freed up resources.
capacityChanged(ResourceConstraints, List<F>) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.CapacityChangeEvent
This function is called by the object that has changed its capacities
capacityListenerManager - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
event handler for capacity changes in terms of added/removed physical machines
capacityManagers - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines
this map lists all the currently controlled PMs and their controllers.
centralRnd - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.util.SeedSyncer
The random generator that will be used by the system components and that is recommended to be used by simulations built on top of DISSECT-CF
changeEvents(VirtualMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.EventSetup
Implementing this function allows the implementor to provide a custom VM state change function
changeEvents(VirtualMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.StartupProcedure
Once the startup state is reached, the VM's boot process is imitated with a single core process which runs on the VM for a given amount of ticks.
checkAllocationsPresence(PhysicalMachine.ResourceAllocation) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
check if a particular resource allocation is really issued by this pm.
checkConnectivity(NetworkNode, NetworkNode) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Determines if there is direct network connection possible between two network nodes
checkVMHost(VirtualMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Determines if the VM is hosted locally in one of the physical machines of this IaaSServie
CloudLoader - Class in hu.mta.sztaki.lpds.cloud.simulator.util
This class offers a simple interface to prepare an IaaSService class based on data loaded from an XML cloud configuration file.
CloudLoader() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.util.CloudLoader
 
collectProcessingReport() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
collects the total processed value from the measured resource spreader
compareTo(MonitorConsumption.SpreadingRecord) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption.SpreadingRecord
a comparator to allow easy ordering of the records based on timestamps.
compareTo(ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
offers a comparator between two constraints objects.
compareTo(Timed) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
a comparator for timed objects based on next events and back preference (those objects will be specified smaller that have an earlier next event - if nextevents are the same then backpreference decides betwen events)
completed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
shows if the resource consumption has successfully completed
completedVMs - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the number of VMs that were using resources from this PM at any time of the PM's existence
completionDistance - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The number of ticks it is expected to take that renders both underProcessing and toBeProcessed as 0 (i.e., the time when the initially specified amount of resources are completely utilized).
conCancelled(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
if we receive a cancelled event we consider it as an unexpected behavior and throw an exception.
conCancelled(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
This function simply marks the failure of the consumption in the cancelled field of the class.
conCancelled(ResourceConsumption) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption.ConsumptionEvent
This function is called when the resource consumption cannot be handled properly - if a consumption is suspended (allowing its migration to some other consumers/providers then this function is not called.
conComplete() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
the notification handler when a task from the tasklist is complete this handler actually sends the next task in.
conComplete() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
This function simply marks the success of the consumption in the completed field of the class.
conComplete() - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption.ConsumptionEvent
This function is called when the resource consumption represented by the ResourceConsumption object is fulfilled
conComplete() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.InitialTransferEvent
stores the newly transferred storage object into the VM's disk field, and then continues with the next step in the VM state management (represented with the event setup)
ConstantConstraints - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints
Defines the non-mutable main resource constraints representation
ConstantConstraints(double, double, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
A constructor to define resource constraints with exact amount of resources
ConstantConstraints(double, double, boolean, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
The main constructor to define resource constraints
ConstantConstraints(ResourceConstraints) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
Allows to make an arbitrary resourceconstraints object into a constant one
ConstantConsumptionModel - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
Defines a power draw model that always returns an instantaneous power draw value equivalent to the minimum consumption set for the current power state.
ConstantConsumptionModel() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.ConstantConsumptionModel
 
consumer - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The consumer which receives the resources of this consumption.
consumerLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
the processing limit imposed because of the consumer WARNING: this is necessary for the internal behavior of MaxMinFairSpreader
consumingStates - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the set of those VM states that are expected to consume energy
ConsumptionEventAdapter - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class simplifies the implementation of consumption events and provides basic functions to determine if a resource consumption has already been completed (either with a failure or success).
ConsumptionEventAdapter() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
 
consumptionRange - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
The power draw range in Watts (the maximum possible offset from minimum power draw)
contents - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Stuff that is already in the current repository
contents() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Offers an unmodifiable list of contents.
cumulativeRC - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
All VMs in the request should have this much resources in total
currentConsumption - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
What is the actual resource consumption (task) that is executed on the PM's direct consumer (i.e.
currentlyStartingPM - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines
ensures that we only have a single machine switching on at a time and shows what is the actual machine that is switching on.
currentlyStartingPMs - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.MultiPMController
the list of machines that are currently turned on by this controller.
currentPowerBehavior - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The power behavior that currently models the resource spreader's energy characteristics.
currentState - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
The current state of the PM
currentStorageUse - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
The current total size of the contents in the actual repository object
currentUnProcessed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
Determines the amount of processing that still remains unspent in this spreader.
currState - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the current state of the VM

D

defaultAllocLen - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
This is the default length for how long a resource allocation will be kept before it becomes invalid.
DeferredEvent - Class in hu.mta.sztaki.lpds.cloud.simulator
Offers the event handling mechanism for non-recurring but time dependent events.
DeferredEvent(long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
Allows constructing objects that will receive an eventAction() call from Timed after delay ticks.
DeferredEvent.AggregatedEventDispatcher - Class in hu.mta.sztaki.lpds.cloud.simulator
handles the event aggregations, actual subscriptions to timed events and dispatches the events if Timed notifies for time instance at which the non-recurring events should be fired Improves the performance of deferred events significantly if multiple events should occur at once
DeferredEvent.AggregatedEventDispatcher() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent.AggregatedEventDispatcher
 
depGroupExtension - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
those resource spreaders that need to be added to the influence group at the particular time instance
depgrouplen - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
The current length of the myDepGroup array.
deployVM(VirtualMachine, PhysicalMachine.ResourceAllocation, Repository) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Bounds a VM to a particular PM on a previously agreed allocation
deregisterHost(PhysicalMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
This function allows the IaaS to reduce in size.
deregisterObject(StorageObject) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
This function is designed to simulate the erase function of the repository given that its user knows the StorageObject to be dropped.
deregisterObject(String) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
This function is designed to simulate the erase function of the repository given that its user knows the identifier of the content to be dropped.
deregisterRepository(Repository) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
This function allows the IaaS to reduce its storage capacities.
destroy(boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Destroys the VM, and cleans up all repositories that could contain disk or memory states.
directConsumer - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
This consumer is added to the PM help simulate the pure (VM less) operations on the PM.
directConsumerUsageMoratory - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
shows when the PM's direct consumer cannot be used as a consumer for tasks (in general it is only usable for external users when the PM is running)
DirectEnergyMeter - Class in hu.mta.sztaki.lpds.cloud.simulator.energy
Direct energy meters can monitor a single resource spreader and can convert their processed consumption values to a continuously updated energy figure.
DirectEnergyMeter(ResourceSpreader) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
sets up the new meter.
disk - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the VM's disk that is stored on the vatarget.
diskid - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.InitialTransferEvent
the expected id of the storage object in the target repository
diskinbws - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Models the write bandwidth of the disk of this network node
diskoutbws - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Models the read bandwidth of the disk of this network node
dispatcherSingleton - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
the aggregator that handles the event list stored in toSweep.
doConsumerProcessing(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
This function simulates how the consumer utilizes the resources from its provider.
doProcessing(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The main resource processing loop.
doProviderProcessing(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
This function simulates how the provider offers the resources for its consumer.
doStorage() - Method in interface hu.mta.sztaki.lpds.cloud.simulator.io.Repository.MainStorageActivity
The action that actually does the depositing of the requested content
dropVMrequest(VirtualMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Cancels a VM request by dropping the corresponding queuing data from the scheduler's queue.
duplicateContent(String, String, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Initiates the duplication of some repository content

E

EnergyMeter - Class in hu.mta.sztaki.lpds.cloud.simulator.energy
Base class for all energy meters.
EnergyMeter() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
 
esetup - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.InitialTransferEvent
the event to be fired after the transfer is complete
ev - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The event to be fired when there is nothing left to process in this consumption.
evaluateConsumption(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.ConstantConsumptionModel
 
evaluateConsumption(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.LinearConsumptionModel
 
evaluateConsumption(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.NoIdleConsumptionModel
 
evaluateConsumption(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState.ConsumptionModel
calculates the instantaneous power draw of a resource spreader under a particular load.
eventAction() - Method in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
When creating a deferred event, implement this function for the actual event handling mechanism of yours.
eventAction() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
This function is called by deferred event when the allocation is expired.
eventArrival - Variable in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
The time instance at which this event should be delivered
expectedState - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.EventSetup
the state that the VM needs to be after the eventsetup completes

F

fetchObjectToMemory(StorageObject, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Allows the modeling of getting an storage object from the disk into the memory.
fire() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
This function allows the manual operation of the event handling mechanism.
fireCounter - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
The actual time in the system.
firstConsumerId - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
The index of the first consumer in the myDepGroup array.
FirstFitScheduler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
This class implements one of the simplest VM schedulers: it places every VM on the first PM that would actually accept it.
FirstFitScheduler(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
the constructor of the scheduler that passes on the parent IaaS service and initiates the basic PM iterator for this scheduler which will
freeCapacities - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
This is the publicly disclosed set of those resources that are not even having an allocation.
freeCapacity - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
This field represents the action to be done when some resources become free on one of the currently running PMs in the IaaS.
freeResourcesSinceLastSchedule - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
In this field the simulator maintains those recently freed up resources that could be allowing a new scheduling run
frequency - Variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
The number of ticks that should pass between two tick() calls.

G

generateTransitions(double, double, double, double, double) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.util.PowerTransitionGenerator
The generator function that derives the power transition and power state definitions from a few simple parameters.
get(int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
only the head of the queue is allowed to be queried
getBgNetworkLoad() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Allows to determine the background network load expected to be simulated between the appliance's hosting repository and the PM that hosts the VM while the VM runs its tasks.
getCapacities() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
returns with the total capacities of this service (cumulative value for all its PMs)
getCapacities() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
collects the total resource capacity of the PM
getCapacities() - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
Allows the query of the total capacities
getClonedDepGroup() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
This will always give a fresh copy of the depgroup which can be changed as the user desires.
getCompletedVMs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
gets the number of VMs that have already left the PM but that were running on it once
getCompletionDistance() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Retrieves the number of ticks it is expected to take that renders both underProcessing and toBeProcessed as 0 (i.e., the time when the initially specified amount of resources are completely utilized).
getConsumer() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Queries the consumer associated with this resource consumption.
getConsumptionRange() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
Allows read access to the consumption range field
getCounterPart(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
Determines what is the provider this consumer is connected with via the resource consumption specified.
getCounterPart(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
Determines what is the consumer this provider is connected with via the resource consumption specified.
getCounterPart(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
If it is unknown whether we are a provider or a consumer (this is usually the case in the generic resource spreader class or anyone outsed the actual provider/consumer implementations) then it is useful to figure out the counter part who also participates in the same resource consumption processing operation.
getCurrentOnOffDelay() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Gets an estimate for the duration (in ticks) of the poweron/off operation in progress.
getCurrentPower(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
determines the current power draw of the system given that it has the load specified in the parameter
getCurrentPowerBehavior() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Queries the current power behavior object
getDepGroup() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Only those should get the depgroup with this function who are not planning to change it's contents.
getDGLen() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
queries the number of resource spreaders that are part of the influence group managed by this freqsyncer.
getDiskbw() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
The bandwidth available when duplicating local disk contents.
getFireCount() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Determines the simulated time that has already passed since the beginning of the simulation (0).
getFirstConsumerId() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
query the index of the first consumer in the influence group's internal array representation
getFreeStorageCapacity() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Retrieves the currently available free space on this repository.
getFrequency() - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Determines the time distance (in ticks) between two tick() calls.
getHandlerInstance() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.PowerStateChangeNotificationHandler
gets the event handler that will manage the notification subscriptions for the particular resource spreader object that asked for the handler.
getHandlerInstance() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.VMStateChangeNotificationHandler
gets the event handler that will manage the subscriptions for the particular VM object that asked for the handler.
getHardLimit() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Determines the hard processing limit for this resource consumption.
getHashandIncCounter() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Manages the increment of the hashCounter and offers the latest hash code for new objects WARNING: as this function does not check if a hash value is already given or not there might be hash collisions if there are so many resource spreaders created that the hashcounter overflows.
getHost() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
Allows to determine the Physical Machine the particular allocation is bound to.
getHostRegEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.AlwaysOnMachines
When a new PM is registered to the IaaS service the below controller automatically turns it on.
getHostRegEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.PhysicalMachineController
Calling this function should return an object which knows what to do in case a new host registration/deregistration happens on the parent IaaS service.
getHostRegEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines
Defines to do the following when a new host is (de)registered to the parent IaaSService: if the current event is a registration event then the function creates and locally registers a new capacity change manager for the newly registered pms if the current event is a deregistration event then the function cancels the capacity management for all deregistered pms
getInputbw() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Determines the total input bandwidth available for the node
getMaxStorageCapacity() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Retrieves the maximum storage capacity of this repository.
getMeteringStarted() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
Allows the reading of the beginning time instance of the metering session If there were several metering sessions done by this meter, then this function reports the time instance when a hypothetical single continuous metering session would have started
getMeteringStopped() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
Enables access to the time when the last reading was stored for the last stopped metering session.
getMinConsumption() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
allows read access to the minconsumption field
getName() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Allows to query the networknode's name
getNextEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Allows the query of the next event at which the tick() function will be called for this object
getNextFire() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Determines the earliest time instance when there is any event in the system to be performed.
getNoResources() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
An easy way to get alterable constraints with zero resources - as a basis for calculations with RCs
getObserved() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.IaaSEnergyMeter
Allows to determine what is the
getObserved() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.PhysicalMachineEnergyMeter
allows determining which PM is under observation
getOutputbw() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Determines the total output bandwidth available for the node
getPerTickProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Determines the current processing power of this resource spreader
getPMIterator() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
Resets the iterator then offers it to the caller
getProcessingLimit() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Retrieves the maximum amount of processing that could be sent from toBeProcessed to underProcessing in a single tick
getProvider() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Queries the provider associated with this resource consumption.
getQueuedVMs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Prepares a list of all the VMs that are queued at the particular moment in time
getQueueingEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.AlwaysOnMachines
Describes an event handler that does nothing upon the start of VM queueing.
getQueueingEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.MultiPMController
Implements a reaction to the starting of the VM queue that is capable to turn on multiple PMs in parallel.
getQueueingEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.PhysicalMachineController
Calling this function should return an object that knows the necessary actions to take when the IaaS's VM scheduler alarms us for overutilized infrastructure.
getQueueingEvent() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines
Defines to do the following when VM requests arrive: check if there is already a PM under preparation (if there is one then does nothing) if there are no PM that is currently prepared then starts to prepare one for accepting VM requests.
getQueueLength() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The number of VM requests queued at the moment
getRealLimit() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Retrieves the processing limit at the particular moment of time (just queries the value last set by the scheduler)
getRequiredCPUs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
getRequiredCPUs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
getRequiredCPUs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
Allows to query how many CPUs this constraints object represent
getRequiredCPUs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
 
getRequiredMemory() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
getRequiredMemory() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
getRequiredMemory() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
Allows to query how much memory this constraints object represent
getRequiredMemory() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
 
getRequiredProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
getRequiredProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
getRequiredProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
Allows to query the performance of a single CPU core represented by this constraints object represent
getRequiredProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
 
getResourceAllocation() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Determines what is the resource allocation currently used by the VM.
getRunningCapacities() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
returns with the total running capacities of this service (cumulative value for all its PMs that are in a running state)
getSamePart(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
Determines what is the consumer referred by the resource consumption specified.
getSamePart(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
Determines what is the provider referred by the resource consumption specified.
getSamePart(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The function gets that particular resource spreader from the given resource consumption object that is the same kind (i.e., provider/consumer) as the resource spreader that calls for this function.
getStartupProcessing() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Allows to determine the number of processing instructions to be done during the startup of the VM that utilizes this VA.
getState() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
retrieves the current state of the PM
getState() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Queries the current state of the VM
getSubDayProcessing() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the amount of processing done in a the past day (this is a rolling day always assumed to start a day before this function was called)
getSubHourProcessing() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the amount of processing done in a the past hour (this is a rolling hour always assumed to start a hour before this function was called)
getSubSecondProcessing() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the amount of processing done in a the past second (this is a rolling second always assumed to start a second before this function was called)
getSyncer() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Determines the influence group this resource spreader is participating in.
getToBeProcessed() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Determines the amount of processing for which no resources were offered from the provider so far.
getTotalConsumption() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.AggregatedEnergyMeter
Calculates the sum of total consumptions returned by each and every supervised meter
getTotalConsumption() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
Allows the reading of the meter's current consumption report.
getTotalConsumption() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.SimpleVMEnergyMeter
cons(PM)/NumVMs(PM)
getTotalProcessed() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Returns the total amount of resources processed (i.e., via all past and present resource consumption objects) by this resource spreader object at the time instance this call is made.
getTotalProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
getTotalProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
getTotalProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
The total processing power of all cores represented by this constraints object: total=cpus*processingpower
getTotalProcessingPower() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
 
getTotalQueued() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The complete resource set required to fulfill the entirety of the VM requests in the queue
getUnderProcessing() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Determines the amount of resoruces already offered by the provider but not yet used by the consumer.
getUnProcessed() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Returns the amount of processing still remaining in this resource consumption.
getVa() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Queries the VA used by this VM

H

halfRealLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
1/2*realLimit
handlerSingleton - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.PowerStateChangeNotificationHandler
the single object that will handle all notification operations on the same way
handlerSingleton - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.VMStateChangeNotificationHandler
the singleton notification sender object that will send out all notifications about a VM state changes on a uniform way
hardLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
the minimum of the perTickProcessing power of the provider/consumer
hashCode() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Returns the constant hashcode that was generated for this object during its instantiation.
hashCounter - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
A continuously increasing simple hash value to be used by the next resource spreader object created
hasNext() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
 
hasNext() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RoundRobinIterator
 
hostPowerBehavior - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Mapping between the various PM states and its representative CPU/memory power behaviors.
hu.mta.sztaki.lpds.cloud.simulator - package hu.mta.sztaki.lpds.cloud.simulator
 
hu.mta.sztaki.lpds.cloud.simulator.energy - package hu.mta.sztaki.lpds.cloud.simulator.energy
 
hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling - package hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
 
hu.mta.sztaki.lpds.cloud.simulator.energy.specialized - package hu.mta.sztaki.lpds.cloud.simulator.energy.specialized
 
hu.mta.sztaki.lpds.cloud.simulator.iaas - package hu.mta.sztaki.lpds.cloud.simulator.iaas
 
hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints - package hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints
 
hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling - package hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling
 
hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel - package hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
 
hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications - package hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications
 
hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling - package hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
 
hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators - package hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators
 
hu.mta.sztaki.lpds.cloud.simulator.io - package hu.mta.sztaki.lpds.cloud.simulator.io
 
hu.mta.sztaki.lpds.cloud.simulator.notifications - package hu.mta.sztaki.lpds.cloud.simulator.notifications
 
hu.mta.sztaki.lpds.cloud.simulator.util - package hu.mta.sztaki.lpds.cloud.simulator.util
 

I

IaaSEnergyMeter - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.specialized
Allows a complete IaaS system to be monitored energywise with single energy metering operations.
IaaSEnergyMeter(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.IaaSEnergyMeter
Allows the construction of a new metering object building on top of the generic aggregated energy meter concept
IaaSService - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class represents a single IaaS service.
IaaSService(Class<? extends Scheduler>, Class<? extends PhysicalMachineController>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Constructs an IaaS service object directly.
IaaSService.IaaSHandlingException - Exception in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class represents a generic error that occurred during the operation of the IaaS service.
IaaSService.IaaSHandlingException(String) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService.IaaSHandlingException
Only a generic constructor is defined so a textual message can be propagated around the system
IaaSService.IaaSHandlingException(String, Throwable) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService.IaaSHandlingException
 
id - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.StorageObject
the identifier of the storage object.
inassginmentprocess - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
A helper field to show if the consumer/providerLimit fields are under update by MaxMinFairSpreader.assignProcessingPower() WARNING: this is necessary for the internal behavior of MaxMinFairSpreader
inbws - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Models the incoming network connections of this network node
increaseTotalConsumption(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
increases the total consumption value with the specified amount.
increasingFreeCapacityListenerManager - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
this notification handler is used to send out events when some of the PM's resources are getting available for others to use
index - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
Current index to be used when the next PM is asked for
indexOf(Object) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
initializeFreqUpdate() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
At the beginning of a freq update cycle, every influence group member is initialised with this function.
initialTransfer(Repository, Repository, VirtualMachine.EventSetup) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Ensures the transfer of the VM to the appropriate location.
initTransfer(long, double, NetworkNode, NetworkNode, ResourceConsumption.ConsumptionEvent) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
This function ensures the proper initialization of an individual transfer.
instantiateIterator() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
Allows the customization of the PM iterator by subclasses.
instantiateIterator() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.RandomScheduler
Returns with the Random PM iterator.
instantiateIterator() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.RoundRobinScheduler
Returns with the RoundRobin PM iterator.
internalAvailableCaps - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the resource set that does not have a VM running on it avaiableCapacities = freeCapacities + promisedCapacities
internalMachines - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
The actual writable list of the machine set maintained behind this IaaSService WARNING: The order of internal machines is not guaranteed
internalReallyFreeCaps - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the amount of resources that are not running a VM or not allocated by some resource allocation
internalRepositories - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
The list of repositories under direct control of this IaaS service - this is for internal purposes the list is writeable The order of internal repositories is not guaranteed
internalRunningMachines - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
The actual writable list of the running machine set maintained behind this IaaSService WARNING: The order of internal running machines is not guaranteed
invokeRealScheduler() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
This function is actually calling the subclass's scheduler implementation and handles the management of minimum scheduler requirements and resets the free resource aggregate
isAcceptableConsumption(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Determines if a resource consumption (i.e., a compute task utilizing the CPU of the PM) can be registered on the PM for execution.
isAcceptableConsumption(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Allows the rejection of the registration of some resource consumptions.
isAcceptableConsumption(ResourceConsumption) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
determines if a resourceconsumption object can be registered.
isAvailable() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
Determines if the allocation is still available to use
isCancelled() - Method in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
Allows to determine whether the actual event was cancelled already or not.
isCancelled() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
Determines whether there was a failure in the resource consumption this event adapter is/was observing
isCompleted() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ConsumptionEventAdapter
Determines if successful completion was marked for the resource consumption this event adapter is/was observing
isConsumer() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
Tells the world that this particular resource spreader is a consumer.
isConsumer() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
Tells the world that this particular resource spreader is a provider.
isConsumer() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Determines if a particular resource spreader is acting as a consumer or not.
isDirectConsumerUsageMoratory() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
determines if the direct consumer accepts compute tasks to be registered
isHostableRequest(ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
checks if at least in theory the requested resources could be hosted on the PM (i.e., when there are no other VMs hosted on the PM).
isHostingVMs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
determines if there are any VMs on the PM or not.
isInDepGroup(ResourceSpreader) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Determines if the spreader in question is part of the current influence group or not
isRegistered() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Determines if the object is registered and resources are used because of this consumption object
isRegisteredHost(PhysicalMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
A function to determine if a host is within the premises of this IaaSService.
isRegularFreqMode() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Determines if the influence group is processing 0 ticks long consumptions.
isRequiredProcessingIsMinimum() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
isRequiredProcessingIsMinimum() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
isRequiredProcessingIsMinimum() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
Determines if the specified amounts of resources are minimally or exactly required.
isRequiredProcessingIsMinimum() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
 
isResumable() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Allows to query whether this resource consumption was cancelled or not
isRunning() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Determines if the machine can be used for VM instantiation.
isSubscribed() - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Allows to determine if a particular timed object is receiving notifications from the system
isUnUsed() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
Allows users to determine if the allocation is already taken by a VM.
it - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
the iterator of the running PMs allowing to easily traverse the PM set in a predefined order.

J

jumpTime(long) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Increases the time with a specific amount of ticks.

L

lastIndexOf(Object) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
lastMetered - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
when was the last metering result collected.
lastNotifTime - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The last time there were some processing operations done by this object.
latencies - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
The direct network connections of this network node.
limitComparator - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
This comparator class provides a simple comparison tool for two resource consumptions based on their real limits.
limithelper - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
the amount of processing that can be surely done by both the provider and the consumer.
LinearConsumptionModel - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
Defines a power draw model that interpolates the returned instantaneous power draw values between the minimum and maximum power draw values from the power state.
LinearConsumptionModel() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.LinearConsumptionModel
 
listeners - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
the list of those objects who are prepared to handle power state changes
listeners - Variable in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
The listeners that will receive notifications if the notify listeners function is called
listIterator() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
listIterator(int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
listVMs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
lists all VMs running or requested (and queued at a VM scheduler) from the IaaSservice
listVMs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
a method to query the currently running VMs (this can also be accessed through the public field of publicVms).
listVMs() - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
Provides an overview on the VMs currently in the system
loadNodes(String) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.util.CloudLoader
Offers the IaaSService creator functionality by defining the sax parser for the XML cloud configuration.
localDisk - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the internal disk of the physical machine.
lookup(String) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Searches and returns the storage object with a given identifier

M

machines - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
publicly available read only version of the internal machines field
mainNotificationLoop(P) - Method in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
The main event dispatching loop.
manageQueueRemoval(QueueingData) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Removes an arbitrary item from the queue (could be a rather slow operation!)
manageQueueRemoval() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Removes the head of the queue
manageStoragePromise(long, String, Repository, Repository.MainStorageActivity) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Manages the promisedStorage field of repository objects.
marked - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
The index of the PM that was marked - this allows the users of the iterator to remember particular positions in the PM list
markLastCollected() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
This call can mark the last PM that was offered by the iterator with its previous next() call.
maxIndex - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
The total amount of PMs the iterator should go thorough - this is assumed not to change until a new reset function call.
MaxMinConsumer - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class is part of the unified resource consumption model of DISSECT-CF.
MaxMinConsumer(double) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
Constructs a generic Max Min fairness based resource consumer.
MaxMinFairSpreader - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class is part of the unified resource consumption model of DISSECT-CF.
MaxMinFairSpreader(double) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
Constructs a generic Max Min fairness based resource spreader.
MaxMinProvider - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class is part of the unified resource consumption model of DISSECT-CF.
MaxMinProvider(double) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
Constructs a generic Max Min fairness based resource producer.
maxProcessable - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
the maximum amount of totalprocessed increase possible during the metering time interval.
maxStorageCapacity - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
The total possible size of the contents in the current repository
measuredResource - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
the resource spreader that needs to be measured energywise
meminbws - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Models the memory write bandwidth on this network node
memoutbws - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Models the memory read bandwidth on this network node
meteringStarted - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
determines the time instance when the current metering session has started.
meteringStopped - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
when did the metering stopped reported in absolute time.
migrate(PhysicalMachine.ResourceAllocation) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Moves all data necessary for the VMs execution from its current physical machine to another.
migrateVM(VirtualMachine, IaaSService) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Not implemented! Will allow migrating VMs across IaaSServices.
migrateVM(VirtualMachine, PhysicalMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Initiates the migration of a VM to another PM.
migrateVM(VirtualMachine, E) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
Migrates a VM from the current system to another.
migrationAllocLen - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
This is the recommended length for how long a resource allocation will be kept before it becomes invalid in case the allocation is made for a VM migration.
minConsumption - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
The minimum instantaneous power draw in W
minimumSchedulerRequirement - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Here we keep an account of the amount of resources a particular scheduler would need before it would be able to schedule a new VM request
model - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
The current consumption model (which transforms the load to wattage based on the power state's charactheristics (e.g., mincons/range)
MonitorConsumption - Class in hu.mta.sztaki.lpds.cloud.simulator.energy
This class is an initial framework to collect periodical reports on consumptions.
MonitorConsumption(ResourceSpreader, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
Initiates a monitoring session for the resource consumptions of a particular resource spreader
MonitorConsumption.SpreadingRecord - Class in hu.mta.sztaki.lpds.cloud.simulator.energy
the collected totalprocessed data with timestamps to allow seeing the temporal behavior of totalprocessed
MonitorConsumption.SpreadingRecord() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption.SpreadingRecord
 
multiply(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Allows to increase/decrease the amount of cpu cores and required memory by this constraints object linearly
MultiPMController - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling
A reactive PM controller that increases/decreases the powered on pm set on demands of the vm scheduler.
MultiPMController(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.MultiPMController
Constructs the scheduler and passes the parent IaaSService to the superclass.
myDepGroup - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
The influence group managed by this freqsyncer object.
myHandler - Variable in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
the entity that is actually used to perform the notifications
myHashCode - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The hashcode of the actual resource spreader to be used in java's built in hashCode function
myPowerState - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState.ConsumptionModel
backlink to the power state with useful data to determine the consumption model
myPromisedIndex - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
The index of this allocation in the allocation list located in the PM.
mySyncer - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The influence group in which this resource spreader belongs.

N

name - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
The name of this network node (this could be an IP or what is most suitable for the simulation at hand).
negligableProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
For floating point operations using the perTickProcessingPower this defines the precision, ie.
NetworkNode - Class in hu.mta.sztaki.lpds.cloud.simulator.io
This class represents a networked element in the system.
NetworkNode(String, long, long, long, Map<String, Integer>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
This function initializes the bandwidth spreaders for the node to ensure equal network share for each transfer occurring on the node.
NetworkNode.NetworkException - Exception in hu.mta.sztaki.lpds.cloud.simulator.io
 
NetworkNode.NetworkException(String) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode.NetworkException
 
NetworkNode.SingleTransfer - Class in hu.mta.sztaki.lpds.cloud.simulator.io
The instances of this class represent an individual data transfer in the system.
NetworkNode.SingleTransfer(int, long, double, MaxMinConsumer, MaxMinProvider, ResourceConsumption.ConsumptionEvent) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode.SingleTransfer
This constructor describes the basic properties of an individual transfer.
networkPowerBehavior - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Mapping between the various PM states and its representative network power behaviors.
newComputeTask(double, double, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
This is the function that users are expected to use to create computing tasks on the VMs (not using resourceconsumptions directly).
newCopy(String) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.StorageObject
creates a new storage object based on the current one, but with new name.
newCopy(String) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
creates an object that holds the exact copy of the current virtual appliance with a different id Please note this copy is not going to be registered in any repositories (unlike the other VA), nor will it be used by any virtual machines.
newListeners - Variable in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
if the notificaiton process is underway, then new listeners are registered here (they will not receive notifications in the current notification round as their registration is actually a result of the current notification round)
newState - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
The state that the delayer must switch to after the power state change has finished its activites.
next() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
 
next() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RandomIterator
 
next() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RoundRobinIterator
 
nextEvent - Variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Specifies the next time (in ticks) when the recurring event should be fired.
nextEventDistance() - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Determines the next event at which point this object will receive a tick() call.
noEventDispatchingInProcess - Variable in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
a marker to show if there is a notification process underway
NoIdleConsumptionModel - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
Defines a power draw model that either uses the LinearConsumptionModel to determine the power draw of uses 0W power draw value if there is no load specified.
NoIdleConsumptionModel() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.NoIdleConsumptionModel
 
NonQueueingScheduler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
This class offers a scheduler implementation that practically eliminates the use of the queue.
NonQueueingScheduler(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.NonQueueingScheduler
Passes the IaaSService further to its super class.
noResources - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
Provides easy access to the one and original zero constraints
notifyCharacteristisListeners() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
used to send out notifications before any of the power state characteristics change
notifyListeners(P) - Method in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
Sends out the notifications via the user defined event handler for all currently listed listeners.
nudge() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
To be used to initiate out of order frequency updates.
nudged - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
if there are some external activities that could lead to influence group changes this field will be turned to true the tick function then ensures it to return to false once it has completed its management operations on the influence groups
numofCurrentVMs() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
a method to determine the number of VMs currently hosted by the PM.

O

observed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.IaaSEnergyMeter
The IaaSService to be observed with this meter
observed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.PhysicalMachineEnergyMeter
The physical machine that is under monitoring
observed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines.CapacityChangeManager
the physical machine that this capacity manager will target with its operations
offDelayEstimate - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
around how many ticks the PM is estimated to run the tasks in the offTransition array.
offTransition - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the tasks to do when switching the PM off.
oldCapacity - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.IaaSEnergyMeter
record of the past capacity on the observed IaaSservice (used to determine in which direction did its capacity change).
onDelayEstimate - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
around how many ticks the PM is estimated to run the tasks in the onTransition array.
onOffEvent - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
The currently operating state change handler - this field actually shows if a state change is on the way.
onTransition - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the tasks to do when turning the PM on.
orderedPMcache - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
This field contains an automatically updated list of all machines in the parent IaaS.
outbws - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
Models the outgoing network connections of this network node
outOfOrderProcessing(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Goes through the entire influence group and for each member it initiates its doProcessing function.

P

parent - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.PhysicalMachineController
The Infrastructure service that will have the physical machines to be controlled and overseen by the particular implementations of this class
parent - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The IaaS for which this VM scheduler manages the VM requests.
pastNotification - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
Records the last time in ticks when the power characteristics change was propagated to listeners
perTickProcessingPower - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Maximum amount of resources to be shared among the consumption objects during a single tick.
PhysicalMachine - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class represents a single Physical machine with computing resources as well as local disks and network connections.
PhysicalMachine(double, double, long, Repository, int, int, EnumMap<PhysicalMachine.PowerStateKind, EnumMap<PhysicalMachine.State, PowerState>>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Defines a new physical machine, ensures that there are no VMs running so far
PhysicalMachine(double, double, long, Repository, double[], double[], EnumMap<PhysicalMachine.PowerStateKind, EnumMap<PhysicalMachine.State, PowerState>>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Defines a new physical machine, ensures that there are no VMs running so far
PhysicalMachine.PowerStateDelayer - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class handles the delays and activites during the power state change procedures (e.g., switching off/turning on)
PhysicalMachine.PowerStateDelayer(double[], PhysicalMachine.State) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
The constructor of the delayer, it allows the specification of the tasks (that represent the boot/shutdown or similar operations) to be done before the power state can be achieved.
PhysicalMachine.PowerStateKind - Enum in hu.mta.sztaki.lpds.cloud.simulator.iaas
When defining powertransitions for the PM one has to label each transiton's properties with a kind
PhysicalMachine.PowerStateKind() - Constructor for enum hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateKind
 
PhysicalMachine.ResourceAllocation - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class is strongly connected with the physical machine's class, the two are collaborating to allow a fluid and minimal hassle operation of allocating resources on a PM.
PhysicalMachine.ResourceAllocation(ResourceConstraints, ResourceConstraints, int) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
The constructor of the resource allocation to be used by the physical machine only!
PhysicalMachine.State - Enum in hu.mta.sztaki.lpds.cloud.simulator.iaas
Represents the possible states of the physical machines modeled in the system
PhysicalMachine.State() - Constructor for enum hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.State
 
PhysicalMachine.StateChangeListener - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas
Defines the minimal interface for listeners on PM state changes.
PhysicalMachineController - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling
This class contains the main interface for the schedulers of Physical machine states.
PhysicalMachineController(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.PhysicalMachineController
The main constructor which initiates the class and manages the subscriptions to the necessary basic events
PhysicalMachineEnergyMeter - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.specialized
Allows to energy meter all resource spreaders (e.g.
PhysicalMachineEnergyMeter(PhysicalMachine) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.PhysicalMachineEnergyMeter
instantiates a physical machine meter based on the meter aggregator concept of DISSECT-CF
pmCacheLen - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
current length of the pm cache so we don't need to query its size all the time
pmComparator - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
A PM comparator that offers inverse ordering of PMs if used during sort
pmcontroller - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
the PM scheduler applied by this IaaSService object
PMIterator - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators
Provides the archetype of PM iterators.
PMIterator(List<PhysicalMachine>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
Constructs the PM list and stores the received list internally.
pmList - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
The PM list to be operated on.
pmstateChanged - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
This is the action that takes place when one of the PMs at the IaaS changes its state.
PowerBehaviorChangeListener - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This interface should be implemented in case one would like to observe the power behavior changes of a resource spreader.
powerBehaviorListenerManager - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
This is the notification handler object that belongs to this particular resource spreader.
PowerState - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
Represents a particular power state of a resource spreader
PowerState(double, double, Class<? extends PowerState.ConsumptionModel>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
Allow the creation of a new power state object with initial power state characteristics.
PowerState.ConsumptionModel - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
By sub-classing this class one can define arbitrary consumption models.
PowerState.ConsumptionModel() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState.ConsumptionModel
 
PowerState.PowerCharacteristicsChange - Interface in hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling
allows notifications before the consumption characteristics would change.
PowerStateChangeNotificationHandler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications
implements a notification handler for sending out notifications about power state changes in resource spreaders
PowerStateChangeNotificationHandler() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.PowerStateChangeNotificationHandler
disables the instantiation of the handler so we really just have a single instance for all handling operations
PowerTransitionGenerator - Class in hu.mta.sztaki.lpds.cloud.simulator.util
This helper class provides a simple way to generate the necessary power transition functions for physical machine behavior.
PowerTransitionGenerator() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.util.PowerTransitionGenerator
 
prepare(Repository, Repository) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Prepares the VM so it can be started without the need to clone its VA first.
prepareTransitionalTasks(boolean, double[]) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Makes a copy of the given array to the correct target (on/offTransition), and calculates the estimates for the on/offDelay
prePowerChangeEvent(PowerState) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
if the power state of the resource spreader changes then the meter is readjusted for the new power state - this usually means the meter collects all uncolledted resource consumption related information from the spreader
prePowerChangeEvent(PowerState) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState.PowerCharacteristicsChange
this function is called when there is a powerstate characteristic change on the powerstate onMe.
preScheduleState - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the set of states that show that a VM scheduler was not able to schedule the VM (maybe just yet)
preStartupStates - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the states that can preceed the startup phase
previousProcessingReport - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
the last collected totalProcessed value from the meteredResource.
processingLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
the maximum amount of processing that could be sent from toBeProcessed to underProcessing in a tick
processSingleConsumption(ResourceConsumption, long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
Uses the resource consumption's consumer related processing operation to actually use the results of a resource consumption (e.g.
processSingleConsumption(ResourceConsumption, long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
Uses the resource consumption's provider related processing operation to actually offer the resources to those who are in need of them (e.g.
processSingleConsumption(ResourceConsumption, long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
This function is expected to realign the underProcessing and toBeProcessed fields of the ResourceConsumption object it receives.
promisedAllocationsCount - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the amount of resource allocations in the promisedResources array.
promisedCapacities - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the amount of resources currently allocated but that have no VM assigned to them
promisedCapacityUpdater() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
updates the PM's respective fields about resource availability
promisedResources - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
this is the array of resource allocations which contain all not yet used/expired resource allocations.
promisedStorage - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
The amount of contents that are about to arrive.
provider - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The provider which offers the resources for this consumption.
providerLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The processing limit imposed because of the provider WARNING: this is necessary for the internal behavior of MaxMinFairSpreader
publicRCap - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
The capacity of the running machines to be reported externally.
publicTCap - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
the total capacity to be reported for external users.
publicTQ - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
the public version of totalQueued that mirrors its contents but does not allow changes on it
publicVms - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the publicly available, read only set of currently running virtual machines on this PM
pushFromMemory(long, double, boolean, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
This function allows the simplified creation of singletransfer objects for modeling the operation of writing data to the disk/network of this node from its memory.

Q

queue - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The queue of the scheduler.
queuedRC - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
A single VM should have this much resources allocated to it
queuedRepo - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
The repository that is storing the VM's virtual appliance.
queuedVMs - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
The VMs to be placed on a PM
QueueingData - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
The data stored about a single queued VM request.
QueueingData(VirtualMachine[], ResourceConstraints, Repository, Map<String, Object>, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
Instantiates the queueing data object which auto-populates the derivable fields and safeguards all data stored.
queueingEvent - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.PhysicalMachineController
The event consumer object that will get notifications if the VM scheduler of the IaaS is under stress.
queueingStarted() - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler.QueueingEvent
This function is called when the VM scheduler believes the infrastructure could be improved for better suiting its needs.
queueListenerManager - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
the manager of those objects who shown interest in receiving queuing related event notifications

R

ra - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the resource allocation of this VM (this is only not null when the VM is actually running on a pm, or about to run)
raBiggestNotSuitable - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
the largest allocation that was possible to collect from all running PMs in the infrastructure.
randomIndexes - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RandomIterator
The actual order of the indexes used when returning the next PM
RandomIterator - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators
The user of the iterator will not know the order in which the PMs are iterated through.
RandomIterator(List<PhysicalMachine>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RandomIterator
The constructor of the random iterator just passes the pm list to its superclass.
RandomScheduler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
Provides a scheduler that uses the random PM iterator to traverse through the IaaS's running machines list.
RandomScheduler(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.RandomScheduler
Passes the IaaSService further to its super class.
ras - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
The set of resource allocations made for the current VM request (this is important for multi VM requests)
readjustMeter() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
Allows internal realignment to new metering situations that need an immediate utilization reading
readToMemory(long, double, boolean, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
This function allows the simplified creation of singletransfer objects for modeling the operation of reading data from the disk/network of this node to its memory.
realAllocated - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
The resource set that is actually reserved on the PM.
realDeregistration(PhysicalMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Really deregisters a PM from the list of PMs.
realLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The processing limit at the particular moment of time (this is set by the scheduler) This limit is derived from the provider/consumerLimits.
reallocateResources(VirtualMachine, ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
NOT IMPLEMENTED! Reallocates the VM's resources according to the newresources on the host of the VM.
reallocateResources(VirtualMachine, ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Not implemented, would allow VMs to receive more resources in the future
reallocateResources(VirtualMachine, ResourceConstraints) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
Allows fine-grained resource utilization setup of the particular VM after it was allocated on the system.
realResume() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Actually manages the resume operation (could be invoked from migration as well as from resume)
realSubscribe(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
The actual subscription function that is behind updateFreq or subcribe
received - Variable in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
Shows if the event was dispatched already
receivedTime - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
The time stamp when the VM request has been received by the VM scheduler
registerConsumption() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Initiates the processing of a resource consumption.
registerConsumption(ResourceConsumption) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
When a new consumption is initiated it must be registered to the corresponding spreader with this function.
registered - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
shows if the consumption object actually participates in the resource sharing machanism.
registerHost(PhysicalMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
This function allows the IaaS to grow in size with a single PM
registerObject(StorageObject) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
This function is designed to initially set up the repository contents.
registerRepository(Repository) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
This function allows the IaaS to grow its storage capacities
regularFreqMode - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
if the freqsyncer identifies the need to fire events with 0 frequency then it turns this mode off.
release() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
If a VM no longer needs the resources then this function must be called.
remove() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
Remove is not supported in PM iterators!
remove(int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Only the head of the queue can be removed!
removeAndReplaceWithLast(ArrayList<T>, T) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.util.ArrayHandler
An item removal function that brings the last element from the array to the place of the to be removed item.
removeTheseConsumptions(ResourceConsumption[], int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Allows the management of the underRemoval list.
repositories - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
the read only list of all repositories in the system
Repository - Class in hu.mta.sztaki.lpds.cloud.simulator.io
This class represents the storage entities in the system.
Repository(long, String, long, long, long, Map<String, Integer>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Constructor for repository objects
Repository.MainStorageActivity - Interface in hu.mta.sztaki.lpds.cloud.simulator.io
An internal interface for managing storage related operations
requestContentDelivery(String, Repository, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Initiates transfer from a remote location
requestContentDelivery(String, String, Repository, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
This function registers a storage object for transfer.
requestedLimit - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
the user requested processing limit
requestVM(VirtualAppliance, ResourceConstraints, Repository, int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Allows the request of multiple VMs without propagating any scheduling constraints.
requestVM(VirtualAppliance, ResourceConstraints, Repository, int, HashMap<String, Object>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Allows the request of multiple VMs.
requestVM(VirtualAppliance, ResourceConstraints, Repository, int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Initiates a VM on this physical machine.
requestVM(VirtualAppliance, ResourceConstraints, Repository, int, HashMap<String, Object>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Requests a few VMs just as before.
requestVM(VirtualAppliance, ResourceConstraints, Repository, int, HashMap<String, Object>) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
Creates a new VM in the system and immediately returns with a new VM object.
requiredCPUs - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
requiredCPUs - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
requiredMemory - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
requiredMemory - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
requiredProcessingIsMinimum - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
requiredProcessingIsMinimum - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
requiredProcessingPower - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
requiredProcessingPower - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
reset() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
Allows the cleanup of all events registered with the aggregator.
reset() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
Prepares the iterator so its other functions will now operate properly.
reset() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RandomIterator
Does a regular PM iterator reset, then it provides a new random sequence for the iteration.
reset() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RoundRobinIterator
Other than doing regular PM iterator reset, it also reinstantiates the index to keep it from overflowing.
resetCentral() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.util.SeedSyncer
To restart the simulator's random generator
resetCounter - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RandomIterator
A counter to show how many times the reset was called.
resetTimed() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Cancels all timed events and sets back the time to 0.
ResourceConstraints - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints
This class defines the basic properties (cpu core count, per core processing power, and memory size) and operations on resoruce constraints.
ResourceConstraints() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
 
ResourceConsumption - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class is part of the unified resource consumption model of DISSECT-CF.
ResourceConsumption(double, double, ResourceSpreader, ResourceSpreader, ResourceConsumption.ConsumptionEvent) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
This constructor describes the basic properties of an individual resource consumption.
ResourceConsumption.ConsumptionEvent - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This interface allows its implementors to get notified when a consumption completes.
ResourceSpreader - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class is part of the unified resource consumption model of DISSECT-CF.
ResourceSpreader(double) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
This constructor just saves the processing power that can be spread in every tick by the newly instantiated spreader.
ResourceSpreader.FreqSyncer - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel
This class is the core part of the unified resource consumption model of DISSECT-CF.
ResourceSpreader.FreqSyncer(ResourceSpreader, ResourceSpreader) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Constructor of a freqsyncer to be used when neither the provider nor the consumer of a resource consumption belongs to an already existing influence group.
ResourceSpreader.FreqSyncer(ResourceSpreader[], int, int) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
The constructor to be used when a new influence group needs to be created because the original group got fragmented.
restart(boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.PMIterator
Allows the iterator to restart the iteration from the beginning or from a previously remembered position.
restart(boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RoundRobinIterator
marks the index at which the iteration cycle must stop
resumable - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
shows if the consumption was suspended (true) or not.
resume() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Resumes an already suspended VM.
resumeAfterMigration(PhysicalMachine.ResourceAllocation) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
This function is called after the disk and memory images of the VM are located on its new hosting repository.
RoundRobinIterator - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators
This iterator alters the restart operator so it no longer resets the pointer of the PM iterator but instead it marks the last PM encountered during the previous iteration.
RoundRobinIterator(List<PhysicalMachine>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RoundRobinIterator
The constructor of the round robin iterator just passes the pm list to its superclass.
RoundRobinScheduler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
Provides a scheduler that uses the round robin PM iterator to traverse through the IaaS's running machines list.
RoundRobinScheduler(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.RoundRobinScheduler
Passes the IaaSService further to its super class.
runningCapacity - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
the capacity of the machines that are actually running in the system - this is for internal use only again
runningMachines - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
publicly available read only version of the internal running machines field

S

savedmemory - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
if the VM is suspended then its memory is saved in the following storage object.
sched - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
the VM scheduler applied by this IaaSservice object
scheduleQueued() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.FirstFitScheduler
The actual first fit scheduling implementation.
scheduleQueued() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.NonQueueingScheduler
The actual scheduling technique that is invoking the first fit scheduler as many times as many times it gets stuck with a VM request in the queue.
scheduleQueued() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
When a new VM scheduler is created this is the function to be implemented.
Scheduler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
The base class for all VM schedulers, provides the foundational logic and simplifies the implementation of VM schedulers by allowing them to mainly focus on their scheduling logic.
Scheduler(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The main constructor of all schedulers.
Scheduler.QueueingEvent - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
Implementing this interface allows the implementor to receive events from the scheduler about cases when it believes the infrastructure is not sufficient for its needs.
scheduleVMrequest(VirtualMachine[], ResourceConstraints, Repository, HashMap<String, Object>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The main entry point to the schedulers.
schedulingConstraints - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
Data for custom schedulers (e.g., like specific placement requirements - please put me on this machine and this machine only), if null then there is no data.
SchedulingDependentMachines - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling
A reactive PM controller that increases/decreases the powered on pm set on demands of the vm scheduler.
SchedulingDependentMachines(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines
Constructs the scheduler and passes the parent IaaSService to the superclass.
SchedulingDependentMachines.CapacityChangeManager - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling
The main PM control mechanisms are implemented in this class The class basically controls a single PM.
SchedulingDependentMachines.CapacityChangeManager(PhysicalMachine) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines.CapacityChangeManager
This constructor is expected to be used once a PM is registered to the parent IaaSService.
sdEvent - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
The operations to do on shutdown
seed - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.util.SeedSyncer
The random seed for the central random generator.
SeedSyncer - Class in hu.mta.sztaki.lpds.cloud.simulator.util
A class to manage the random generator to be used if reproducible but random results are expected from the simulator
SeedSyncer() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.util.SeedSyncer
 
sendNotification(PowerBehaviorChangeListener, Pair<ResourceSpreader, PowerState>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.PowerStateChangeNotificationHandler
The event handling mechanism for power state change notifications about resource spreaders
sendNotification(VirtualMachine.StateChange, Triple<VirtualMachine, VirtualMachine.State, VirtualMachine.State>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.VMStateChangeNotificationHandler
The event handling mechanism for VM state change notifications
sendNotification(T, P) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.notifications.SingleNotificationHandler
this function is called by the statedependenteventhandler class when a notification is needed for a particular kind of event.
sendTask() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
this function picks the next item (i.e.
serialVersionUID - Static variable in exception hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService.IaaSHandlingException
 
serialVersionUID - Static variable in exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.StateChangeException
 
serialVersionUID - Static variable in exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.NoSuchVMException
 
serialVersionUID - Static variable in exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.VMManagementException
 
serialVersionUID - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
 
serialVersionUID - Static variable in exception hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode.NetworkException
 
set(int, QueueingData) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
setBackPreference(boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Enables to set the back preference of a particular timed object.
setBgNetworkLoad(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Allows to set the background network load expected to be simulated between the appliance's hosting repository and the PM that hosts the VM while the VM runs its tasks.
setConsumer(ResourceSpreader) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Allows to set a consumer for the consumption if the consumption is not yet under way.
setConsumptionRange(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
Allows to set the consumption range for this power state (good for DVFS and similar behavior).
setCurrentPowerBehavior(PowerState) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Allows to change the power behavior of the resource spreader.
setDetails(double, long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Allows updating the appliance's properties in a single step.
setMinConsumption(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
Allows to set the minimum consumption for this power state (good for DVFS and similar behavior).
setNewState(PhysicalMachine.State) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
if after the list of tasks are completed we need to reach a different power state than initially planned then this is the function to go for.
setNonservable() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
If there are not enough resources for the VM currently, to recover from this state (and allow the VM to be rescheduled) just issue a destroy command on the VM
setPerTickProcessingPower(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Allows to set the current processing power of this resource spreader WARNING: this is not intended to be used for altering the performance of the spreader while it participates in resource consumption processing
setProvider(ResourceSpreader) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Allows to set a provider for the consumption if the consumption is not yet under way.
setRealLimit(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Simultaneously updates the real limit (the instantaneous processing limit determined by the low level scheduler of the unified resoruce sharing model of DISSECT-CF) value as well as the halfreallimit field.
setResourceAllocation(PhysicalMachine.ResourceAllocation) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Allows to set a new resource allocation for the VM This function will notify the resource allocation about the acquiration of the resources by utilizing the use function!
setStartupProcessing(double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Allows to set the number of processing instructions to be done during the startup of the VM that utilizes this VA.
setState(PhysicalMachine.State) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
manages the state change operation of the PM.
setState(VirtualMachine.State) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Always use this function to set the current VM state.
simpleAddition(ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Allows a single resource constraints object to be added to this one WARNING: this is for internal purposes only.
SimpleVMEnergyMeter - Class in hu.mta.sztaki.lpds.cloud.simulator.energy.specialized
Derives VM consumption from its hosting PM.
SimpleVMEnergyMeter(VirtualMachine) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.SimpleVMEnergyMeter
Cannot be created for unallocated VMs!
simulateUntil(long) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Automatically advances the time in the simulation until the specific time instance.
simulateUntilLastEvent() - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Automatically advances the time in the simulation until there are no events remaining in the event queue.
singleAdd(ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Allows a single resource constraints object to be added to this one
singleGroupwiseFreqUpdater() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
This function is the entrance to the lowest level scheduling in DISSECT-CF.
singleGroupwiseFreqUpdater() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The entry to the lowest level schedulers in DISSECT-CF.
SingleNotificationHandler<T,P> - Interface in hu.mta.sztaki.lpds.cloud.simulator.notifications
the handler for a particular kind of notification.
size - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.StorageObject
The actual size of the object.
skipEventsTill(long) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Jumps the time until the time given by the user.
SmallestFirstScheduler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
This class offers a VM scheduler that keeps the VM request queue in order and always places those VM requests first that have the smallest resource demands.
SmallestFirstScheduler(IaaSService) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler
Passes the IaaSService further to its super class.
SmallestFirstScheduler.SFQueue - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling
A priority queue that implements the necessary list related operations used in the first fit scheduler and scheduler classes.
SmallestFirstScheduler.SFQueue() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Prepares the underlying priority queue
smallUtilization - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Amount of processing to be done if the PM need to be underutilized.
startMeter(long, boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.AggregatedEnergyMeter
Dispatches start meter calls to all supervised meters.
startMeter(long, boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
starts the metering session for the particular resource spreader
startMeter(long, boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
Initiates an energy metering session.
startMeter(long, boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.PhysicalMachineEnergyMeter
ensures the newly started metering will consider capacity changes in the PM (e.g.
startupProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
The number of processing instructions to be done during the startup of the VM that utilizes this VA.
stateChanged(PhysicalMachine, PhysicalMachine.State, PhysicalMachine.State) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Implements the PhysicalMachine's state change listener to manage the internalRunningMachines list.
stateChanged(VirtualMachine, VirtualMachine.State, VirtualMachine.State) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
This function is called by the user VM if it is switching states.
stateChanged(PhysicalMachine, PhysicalMachine.State, PhysicalMachine.State) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.StateChangeListener
This function is called by the PM on subscribed objects when a PM's state changes.
stateChanged(PhysicalMachine, PhysicalMachine.State, PhysicalMachine.State) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines.CapacityChangeManager
This function is called when the PM's power state changes.
stateChanged(VirtualMachine, VirtualMachine.State, VirtualMachine.State) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.StateChange
If the state of a VM is changed this function is called on all subscribing implementations.
StateDependentEventHandler<T,P> - Class in hu.mta.sztaki.lpds.cloud.simulator.notifications
The main non-time dependent event handling mechanism in DISSECT-CF.
StateDependentEventHandler(SingleNotificationHandler<T, P>) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
Initialization of the event handling mechanism.
stateListenerManager - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the manager of the PM's state change notifications.
StatesOfHighEnergyConsumption - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
This is the list of PM states that mostly consume energy
stillInDepGroup - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
A helper field that allows the rapid discovery of influence groups by the group's freq syncer object
stopIndex - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.pmiterators.RoundRobinIterator
The index at which the restart took place, and thus we use this as the marker for the end of the iteration instead of the end of the PM list.
stopMeter() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.AggregatedEnergyMeter
Dispatches stop meter calls to all supervised meters
stopMeter() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
stops the metering session for the resource spreader
stopMeter() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
Terminates the metering session, the totalconsumption values will no longer be updated!
stopMeter() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.PhysicalMachineEnergyMeter
terminates the metering session for the aggregation and ensures that we no longer consider capacity changes for the PM as they don't need to be reflected in the metering results anymore
StorageObject - Class in hu.mta.sztaki.lpds.cloud.simulator.io
Represents arbitrary data fragments (e.g.
StorageObject(String) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.StorageObject
Allows the creation of the storage object with unknown size (the simulator will pick a random one!
StorageObject(String, long, boolean) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.StorageObject
Allows the creation of the storage object with an influence on the size of the object
storagePowerBehavior - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Mapping between the various PM states and its representative disk power behaviors.
storeInMemoryObject(StorageObject, ResourceConsumption.ConsumptionEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Allows the modeling of storing data that previously resided in the memory of this repository.
subDayProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the total processing accomplished in the last day
subDayRecords - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
all spreading records collected during the past day
subHourProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the total processing accomplished in the last hour
subHourRecords - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
all spreading records that were collected during the past hour
subList(int, int) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
Not supported operation
subMeterCreator(List<PhysicalMachine>) - Static method in class hu.mta.sztaki.lpds.cloud.simulator.energy.specialized.IaaSEnergyMeter
This function creates a list of PhysicalMachineMeters from a list of physical machines.
subscribe(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Allows Timed objects to subscribe for recurring events with a particular frequency.
subscribePowerBehaviorChangeEvents(PowerBehaviorChangeListener) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
allows interested parties to receive power behavior change events by subscribing with a listener object.
subscribePowerCharacteristicsChanges(PowerState.PowerCharacteristicsChange) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
allows users of this powerstate object to get notifications about power state characteristics changes
subscribeQueueingEvents(Scheduler.QueueingEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Allows third parties to get notified if the scheduler is not satisfied with the current infrastructure (e.g.
subscribeStateChange(VirtualMachine.StateChange) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Use this function to get notified about state changes on this VM
subscribeStateChangeEvents(PhysicalMachine.StateChangeListener) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
manages the subscriptions for state change events
subscribeToCapacityChanges(VMManager.CapacityChangeEvent<PhysicalMachine>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
get notified about capacity changes (PM additions/removals) This call is propagated to StateDependentEventHandler.
subscribeToCapacityChanges(VMManager.CapacityChangeEvent<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
not implemented
subscribeToCapacityChanges(VMManager.CapacityChangeEvent<F>) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
manages the subscriptions for capacity change (increase/decrease) events
subscribeToEvents(T) - Method in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
To get state dependent events one must subscribe to them via this function.
subscribeToIncreasingFreeapacityChanges(VMManager.CapacityChangeEvent<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
manages the subscriptions for free capacity events (i.e.
subSecondProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the amount of processing done in the last second
subtract(ResourceConstraints) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
Subtracts another RC object from this one
supervised - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.AggregatedEnergyMeter
The list of meters that supposed to be used together.
susEvent - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
The operations to do on suspend
suspend() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Terminates the consumption but ensures that it will be resumable later on.
suspend() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Suspends an already running VM.
suspend(VirtualMachine.EventSetup) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Just like regular suspend but allows eventsetup hooks.
suspendedStates - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the states in which the VM is suspended to disk
suspendedTasks - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the list of resourceconsumptions (i.e.
swept - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
If the resource allocation is not used before its expiry time then this is going to be true!
switchoff(PhysicalMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Starts the turn off procedure for the physical machine so it no longer accepts VM requests but it does not consume anymore
switchoff(boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Switches off an already running machine.
switchoffmachine() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines.CapacityChangeManager
Allows the observed PM to be switched off and its exceptions handled
switchOn(PhysicalMachine.ResourceAllocation, Repository) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Initiates the startup procedure of a VM.
switchonEvent - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
The operations to do on switchon

T

target - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.InitialTransferEvent
the target repository where the VA is expected to turn up
tasksDue - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
The list of tasks to do for the particular power state change.
terminateVM(VirtualMachine, boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Requesting the destruction of a VM in a DESTROYED state will dequeue the VM from the scheduler's request queue.
terminateVM(VirtualMachine, boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Switches off the VM in question if the VM is hosted by this particular PM.
terminateVM(VirtualMachine, boolean) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
Terminates a VM in the system.
tick(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent.AggregatedEventDispatcher
The actual event dispatcher.
tick(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.AggregatedEnergyMeter
This operation is ignored as the actual metering is done in the supervised meters, and the totalconsumption values are always calculated on demand.
tick(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
Maintains the totalconsumption value in every desired time interval
tick(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
Data collector function that updates all processing data records and throws out the too old records as well.
tick(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Implementation of Algorithm 1 from "DISSECT-CF: a simulator to foster energy-aware scheduling in infrastructure clouds" Manages the influence group's growth and decomposition.
tick(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
This function will be called on all timed objects which asked for a recurring event notification at a given time instance.
Timed - Class in hu.mta.sztaki.lpds.cloud.simulator
This is the base class for the simulation, every class that should receive timing events should extend this and implement the function named "tick".
Timed() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.Timed
 
timedlist - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
The main container for all recurring events in the system
timestamp - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption.SpreadingRecord
the time in ticks when this record was acquired
toBeAdded - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Public, unmodifiable list of just deregistered resource consumptions
toBeProcessed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The remaining unprocessed entities (e.g., remaining bytes of a transfer) NOTE: as this consumption is generic, it is actually the provider/consumer pair that determines what is the unit of this field
toBeRemoved - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Public, unmodifiable list of just registered resource consumptions
toMonitor - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
what resource spreader to collect the totalprocessed values from
ToOfforOff - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
These are the PM states which are either leading to off or already off.
ToOnorRunning - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
These are the PM states which are either leading to running or already running.
toProcess - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The array of consumption objects that will share the processing power of this spreader.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
offers a convenient human readable output for debugging energy meters and their readings where both the metered resource and its currently reported total consumpiton is printed out
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
A convenient and compact way to represent the main characteristics of this power state.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ResourceConstraints
provides a simple one line representation of resource constraints listing all its inherent properties.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
Provides a convenient way to debug the IaaS.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
Shows basic information about the allocation useful for debugging
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
offers a nice single line format summary of the properties of this PM - good for debugging and tracing.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
provides some textual representation of this consumer, good for debugging and tracing
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
provides some textual representation of this provider, good for debugging and tracing
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Provides a nice formatted output of the resource consumption showing how much processing is under way, how much is still held back and what is the current real limit set by the scheduler.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
provides a textual overview of the influence group with all its members.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Provides a nice formatted single line representation of the spreader.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
A nice single line output for the VM that shows its state and resource allocation as well as the tasks it is running.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.QueueingData
Provides a user readable single line representation of the queued VMs.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.NetworkNode
provides an overview of the network node concentrating on the network's properties.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
provides a summary of this repository good for debugging.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.StorageObject
Provides a compact output of all data represented in this Storage Object.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Provides a compact output of all data represented in this VA.
toString() - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Prints out basic information about this timed object.
toSweep - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent
All deferred events that are due in the future are listed here.
totalCapacities - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the complete resouce set of the pm
totalCapacity - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
the total capacity of all machines in this iaas service, for use only internally in the IaaS service class
totalConsumption - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.EnergyMeter
the currently collected totalConsumption in all metering sessions so far.
totalProcessed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption.SpreadingRecord
the totalprocessed value at the particular time instance
totalProcessed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.MonitorConsumption
the totalprocessed value of the spreader during the last collection
totalProcessed - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
Shows how much processing this spreader done in its lifetime.
totalProcessingPower - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
 
totalProcessingPower - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.ConstantConstraints
 
totalQueued - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
the amount of resources needed for fulfilling all VM requests in the queue
transferringStates - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the set of those VM states that are transferring VM related data
transitionStart - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateDelayer
when did the particular power state transition start
turnon() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
Turns on the physical machine so it allows energy and resource consumption (i.e.
turnOnAMachine() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.MultiPMController
Forwards the single PM turnon request to multi PM turnon.
turnOnAMachine() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.SchedulingDependentMachines
switches on a not yet switched on machine from the parent IaaS's PM set.
turnOnSomeMachines() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.pmscheduling.MultiPMController
Turns on as many PMs as many required to fulfill the total resource requirements of the queued VMs at the VM scheduler of the parent IaasService

U

UFCmessage - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler.SFQueue
A message to show if the scheduler/first fit scheduler implementation would try to use previously unused List operations that were not implmeneted so far.
UnalterableConstraintsPropagator - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints
Allows an alterable resource constraints object to be propagated as unalterable.
UnalterableConstraintsPropagator(ResourceConstraints) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
Allows the construction of the propagator.
unassigned - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
A helper field to show if the particular resource consumption still participates in the scheduling process or if it has already finalized its realLimit value.
unassignedNum - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
The number of resource consumptions for which this spreader still did not assign temporal resource utilization limits - see: p(c,s,t) in the paper titled "DISSECT-CF: a simulator to foster energy-aware scheduling in infrastructure clouds" .
underAddition - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The resource consumptions that got registered to this spreader in the last tick
underProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
The currently processing entities (e.g., a network buffer) NOTE: as this consumption is generic, it is actually the provider/consumer pair that determines what is the unit of this field
underProcessing - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The unalterable array of resource consumption objects.
underProcessing - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.Timed
the event that is currently processed by the event loop.
underProcessingLen - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
the length of the list of toProcess.
underRemoval - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
The resource consumptions that got deregistered from this spreader in the last tick
underTransfer - Variable in class hu.mta.sztaki.lpds.cloud.simulator.io.Repository
Contents that are under transfer, to ensure that we are not allowing the deletion of contents that are being transferred currently
unlimitedProcessing - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
If a resource consumption is not supposed to be limited by anything but the actual resource providers/consumers then this limit could be used in its constructor.
unsubscribe() - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Cancels the future recurrance of this event.
unsubscribeFromCapacityChanges(VMManager.CapacityChangeEvent<PhysicalMachine>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.IaaSService
cancel the notifications about capacity changes (PM additions/removals) This call is propagated to StateDependentEventHandler.
unsubscribeFromCapacityChanges(VMManager.CapacityChangeEvent<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
not implemented
unsubscribeFromCapacityChanges(VMManager.CapacityChangeEvent<F>) - Method in interface hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager
manages the subscriptions for capacity change (increase/decrease) events
unsubscribeFromEvents(T) - Method in class hu.mta.sztaki.lpds.cloud.simulator.notifications.StateDependentEventHandler
If there are no events needed for a particular listener then they can be cancelled here.
unsubscribeFromIncreasingFreeCapacityChanges(VMManager.CapacityChangeEvent<ResourceConstraints>) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
manages the subscriptions for free capacity events (i.e.
unsubscribePowerBehaviorChangeEvents(PowerBehaviorChangeListener) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader
allows parties that got uninterested to cancel the reception of new power behavior change events by unsubscribing with a listener object.
unsubscribePowerCharacteristicsChanges(PowerState.PowerCharacteristicsChange) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.powermodelling.PowerState
if some pary gets uninterested in power state changes this is the way to cancel event notifications about them
unsubscribeQueueingEvents(Scheduler.QueueingEvent) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
Cancels the notifications about queuing events
unsubscribeStateChange(VirtualMachine.StateChange) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Use this function to be no longer notified about state changes on this VM
unsubscribeStateChangeEvents(PhysicalMachine.StateChangeListener) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
manages the subscriptions for state change events
updateConsumptionLimit(ResourceConsumption, double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinConsumer
Translates the consumption limit update request to actually changing a field in the resource consumption that is related to consumers.
updateConsumptionLimit(ResourceConsumption, double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
Supposed to update the consumer/provider specific consumption details.
updateConsumptionLimit(ResourceConsumption, double) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinProvider
Translates the consumption limit update request to actually changing a field in the resource consumption that is related to providers.
updateDispatcher() - Method in class hu.mta.sztaki.lpds.cloud.simulator.DeferredEvent.AggregatedEventDispatcher
after some deferred events are dispatched, this function actually determines the next occurrence of a deferred event (and readjusts the notification frequency for Timed) or if there are no further events registered, the function cancels the notifications
updateEvent(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
A core function that actually manages the frequency and nextevent fields.
updateFieldsUsingNewInterval(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
The maxProcessable field is updated with the metering frequency specified here
updateFrequency(long) - Method in class hu.mta.sztaki.lpds.cloud.simulator.Timed
Allows the alteration of the event frequency independently from subscription.
updateHardLimit() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Provides a unified update method for the hard processing limit (which will become the minimum of the provider's/consumer's per tick processing power) of this consumption.
updateMyFreqNow() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceSpreader.FreqSyncer
Calls out to the low level scheduler of the group to assign processing limits for each consumption in the group and to identify the completion time of the earliest terminating consumption.
updateRealLimit(boolean) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.ResourceConsumption
Sets the real limit based on the scheduler set provider and consumer limits (the smaller is used as real).
updateTotal() - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.AlterableResourceConstraints
the total processing field is updated with this function.
updateTotalQueuedAfterRemoval(QueueingData) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.Scheduler
The common functionality required to manage the update of the total queued field.
upLen - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.resourcemodel.MaxMinFairSpreader
Offers a temporary storage for the size of the current resource consumption list.
use(VirtualMachine) - Method in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
To complete the allocation process the VM must be told to use a particular allocation (e.g.
usedPowerState - Variable in class hu.mta.sztaki.lpds.cloud.simulator.energy.DirectEnergyMeter
the power state the particular measuredResource is in
user - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.ResourceAllocation
The VM that utilizes the allocation in question

V

va - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the virtual appliance that this VM is using for its disk
valueOf(String) - Static method in enum hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.PowerStateKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.State
Returns an array containing the constants of this enum type, in the order they are declared.
vasource - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
where should the VM's virtual appliance be located
vatarget - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
where should the VM's disk storage be placed during the VM's initiation procedure.
VirtualAppliance - Class in hu.mta.sztaki.lpds.cloud.simulator.io
Virtual appliances represent functional virtual machine images in the system.
VirtualAppliance(String, double, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Creates a virtual appliance with default size and variance (for details, see StorageObject)
VirtualAppliance(String, double, long, boolean, long) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.io.VirtualAppliance
Creates a virtual appliance with custom size and size variance.
VirtualMachine - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class represents a single virtual machine in the system.
VirtualMachine(VirtualAppliance) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
Instantiates a VM object
VirtualMachine.EventSetup - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
This internal interface is used to customize internal state change actions in the VM class.
VirtualMachine.EventSetup(VirtualMachine.State) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.EventSetup
 
VirtualMachine.InitialTransferEvent - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
The event that will be received upon the completion of the VA's copy from vasource to vatarget.
VirtualMachine.InitialTransferEvent(Repository, VirtualMachine.EventSetup, String) - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.InitialTransferEvent
Initiates the event handler object
VirtualMachine.StartupProcedure - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas
Provides an implementation of the eventsetup class for the startup procedure which is modelled with a single taks that utilizes a single core of the VM for a specified amount of time (in ticks)
VirtualMachine.StartupProcedure() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.StartupProcedure
initiates the class and remarks that the modeled state should be startup
VirtualMachine.State - Enum in hu.mta.sztaki.lpds.cloud.simulator.iaas
the possible states of a virtual machine in DISSECT-CF.
VirtualMachine.State() - Constructor for enum hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.State
 
VirtualMachine.StateChange - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas
This interface helps to receive events on status changes in virtual machines.
VirtualMachine.StateChangeException - Exception in hu.mta.sztaki.lpds.cloud.simulator.iaas
This class is defined to ensure one can differentiate errors that were caused because the functions on the VM class are called in an improper order.
VirtualMachine.StateChangeException(String) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine.StateChangeException
The constructor allows a textual message so users of this class can see the reason of the exception more clearly without debugging.
VMManager<E,F> - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas
This interface intends to provide a generic overview of the VM management functionalities in a system.
VMManager.CapacityChangeEvent<F> - Interface in hu.mta.sztaki.lpds.cloud.simulator.iaas
The interface to implement for those events where a VMManager object changes its capacity.
VMManager.NoSuchVMException - Exception in hu.mta.sztaki.lpds.cloud.simulator.iaas
Receiving this kind of exception shows that the system does not recognize the VM it should operate on.
VMManager.NoSuchVMException(String) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.NoSuchVMException
 
VMManager.NoSuchVMException(String, Throwable) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.NoSuchVMException
 
VMManager.VMManagementException - Exception in hu.mta.sztaki.lpds.cloud.simulator.iaas
This is a generic class to represent all kinds of problems that could occur while managing VMs on the system.
VMManager.VMManagementException(String) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.VMManagementException
 
VMManager.VMManagementException(String, Throwable) - Constructor for exception hu.mta.sztaki.lpds.cloud.simulator.iaas.VMManager.VMManagementException
 
vmQueueSmallestFirstComparator - Static variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.vmscheduling.SmallestFirstScheduler
This comparator allows ordering the VM request queue primarily by cumulative resource request size and secondarily by request arrival time.
vms - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.PhysicalMachine
the set of currently running virtual machines on this PM
vmStateChangelistenerManager - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.VirtualMachine
the local handler of VM state change events.
VMStateChangeNotificationHandler - Class in hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications
implements a notification handler for sending out notifications about VM state changes
VMStateChangeNotificationHandler() - Constructor for class hu.mta.sztaki.lpds.cloud.simulator.iaas.statenotifications.VMStateChangeNotificationHandler
disables the instantiation of the handler so we really just have a single instance for all handling operations

W

whatToPropagate - Variable in class hu.mta.sztaki.lpds.cloud.simulator.iaas.constraints.UnalterableConstraintsPropagator
The other resource constraints object to encapsulate.

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

Copyright © 2012–2015 University of Innsbruck & MTA SZTAKI. All rights reserved.