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

G

g - Variable in class exploration.paretoExploration.distanceexploration.Knee
 
GanttChart - Class in output
Plot a Gantt Chart from a schedule.
GanttChart() - Constructor for class output.GanttChart
Initialize data structures for Gantt chart object
GanttChart.Record - Class in output
Record of each task in the Gantt chart.
GanttChart.Record(String, int, long, long, String, int) - Constructor for class output.GanttChart.Record
Build a record for Gantt chart
GanttChart.Record(String, int, long, long, String, String) - Constructor for class output.GanttChart.Record
Build a record for Gantt chart
GanttChart.Record(String, int, long, long, String) - Constructor for class output.GanttChart.Record
Build a record for Gantt chart.
GanttChart.Record(int, long, long, String) - Constructor for class output.GanttChart.Record
Build a record for Gantt chart.
ganttChartFileName - Variable in class input.CommandLineArgs
Output Gantt chart file name
gcd(Expression, Expression) - Static method in class spdfcore.stanalys.Expression
Greatest common divisor of two expressions.
generateActorPrecedences() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate constraints for task precedences
generateActorTimeDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Generate start,end times and duration for all the tasks.
generateActorTimeDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
generateActorTimeDefinitions() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate start times, end times and duration of tasks / actors.
generateActorTimeDefinitions() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Generate the actor start times, end times, and actor durations
GenerateAppXmlFromProfile - Class in experiments.others
Generate an application XML file from the profiling information xml generated from the hardware platform.
GenerateAppXmlFromProfile() - Constructor for class experiments.others.GenerateAppXmlFromProfile
 
generateAssertion(BoolExpr) - Method in class solver.Z3Solver
Generate an assertion in Z3 context.
generateBufferAnalysisDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Generate all the definitions required for calculating communication buffer size
generateBufferAnalysisDefinitions() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate all the definitions required for buffer size calculation
generateBufferAtProducerCalculation(String, String, int, int, int, int) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate constraints for calculation of the channel buffer size when the producer of the channel executes.
generateBufferBounds(String, String, int) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate constraints for lower and upper bound on the channel.
generateBufferCalculation() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MutExNonPipelinedScheduling
Generate all the buffer calculations
generateBufferCalculationsPipelined() - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate all the constraints required for calculation of the buffer size in a pipelined schedule.
generateBufferConstraint(int) - Method in interface exploration.interfaces.oneDim.BufferConstraints
Set the buffer size for exploration query.
generateBufferConstraint(int) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
 
generateBufferConstraint(int) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
 
generateClusterConstraint(int) - Method in interface exploration.interfaces.oneDim.ClusterConstraints
Set total number of clusters used as a constraint.
generateClusterConstraint(int) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
generateClusterConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
generateClusterConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
generateColorBook() - Method in class output.GanttChart
Assign a color to each actor.
generateCommunicationCostConstraint(int) - Method in interface exploration.interfaces.oneDim.CommunicationCostConstraints
Sets the Communication cost constraint for the exploration query
generateCommunicationCostConstraint(int) - Method in class solver.distributedMemory.mapping.MappingCommSolver
 
generateCommunicationCostConstraint(int) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
generateCommunicationCostConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
generateCommunicationCostConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
generateCommunicationCostConstraint(int) - Method in class solver.distributedMemory.placement.GenericPlacementSolver
 
generateCpuBounds() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate constraints for lower and upper bounds on processor allocated to tasks.
generateCpuDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Generate definitions for processor allocation of all the tasks
generateCpuDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
generateCpuDefinitions() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Define variables for processor allocation of tasks
generateCpuDefinitions() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Define variables for processor allocation of tasks
generateDotFile(String[]) - Static method in class experiments.others.ParseKalrayHardwareLog
Generate DOT files of application graph.
generateDotFromGraph(Graph, String) - Method in class output.DotGraph
This function generates a Dot File from the input graph structure.
generateGanttCharts - Static variable in class experiments.sharedMemory.threeDimension.LatProcBuffExploration
If true, the after exploration it will generate gantt charts for every Pareto Point.
generateGanttCharts - Static variable in class experiments.sharedMemory.twoDimension.LatProcExploration
If true, the after exploration it will generate Gantt charts for every Pareto Point.
generateInitialTokensCalculation(String, String, int, int, int, int) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate constraints to calculate the initial tokens in the channel at the start of the period.
generateJpgFromGraph(Graph, String) - Method in class output.DotGraph
This function generates a JPEG File from the input graph structure.
generateKvariableCalculations() - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate SMT constraints for K-Variable Calculations.
generateLatencyCalculation() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Generate latency calculation for the application graph.
generateLatencyCalculation() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
generateLatencyCalculation() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate constraints to calculate latency of the schedule
generateLatencyCalculation() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Generate latency calculation for the schedule
generateLatencyCalculation() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Generate latency calculation of the schedule
generateLatencyConstraint(int) - Method in interface exploration.interfaces.oneDim.LatencyConstraints
Set the latency constraint for exploration query.
generateLatencyConstraint(int) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
 
generateLatencyConstraint(int) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
generateLatencyConstraint(int) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
 
generateLatencyConstraint(int) - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
 
generateLatencyConstraint(int) - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
 
generateLeftEdgeCpuDefinitions(boolean) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver.LeftEdge
Generate the SMT variable definitions required to calculate the processor utilization.
generateLeftEdgeDefinitions() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MutExNonPipelinedScheduling.LeftEdgeNonPipelined
Generate all the variables to solve the problem
generateLeftEdgePipelinedConstraints() - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling.LeftEdgePipelined
Generate all the constraints required for left-edge scheduling for pipelined mode.
generateMappingConstraints() - Method in class solver.distributedMemory.mapping.MappingCommSolver
Generate all the constraints required to solve this mapping problem.
generateMaxBufferCalculation(String, String, int) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate constraints to calculate maximum buffer size of a channel.
generateMaxWorkloadPerClusterConstraint(int) - Method in interface exploration.interfaces.oneDim.MaxWorkLoadPerCluster
Set the maximum workload per cluster constraint for exploration query.
generateMaxWorkloadPerClusterConstraint(int) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
generateMaxWorkloadPerClusterConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
generateMaxWorkloadPerClusterConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
generateModel() - Method in class graphanalysis.scheduling.ListScheduling
Generate a model from the schedule.
generateMultiplicityGraph() - Method in class underDevelopment.QuasiStaticScheduling
 
generateMutualExclusion() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate the mutual exclusion constraints
generateNonLazySchedule(HashMap<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined.OptimizeSchedule
Generate a non-lazy schedule from the loose schedule obtained
generateOutput(Graph, String) - Method in class output.GenerateSdfXml
Generate Application Graph XML file
generatePartitioningConstraints() - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
Generate all the partitioning constraints
generatePartitioningConstraints() - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
generatePartitioningConstraints() - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
generatePdf(String) - Method in class output.GanttChart
Generate PDF from GNU plot.
generatePdfOutput - Variable in class output.GanttChart
Generate PDF output.
generatePeriodConstraint(int) - Method in interface exploration.interfaces.oneDim.PeriodConstraints
Set the period constraint for exploration query.
generatePeriodConstraint(int) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
generatePeriodConstraint(int) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate period cost for a problem
generatePeriodConstraint(int) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
 
generatePeriodConstraint(int) - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
 
generatePlacementConstraints() - Method in class solver.distributedMemory.placement.GenericPlacementSolver
Generate all the placement constraints required to solve the problem.
generatePredecessorsList() - Method in class graphanalysis.scheduling.ListScheduling
Generate a list of all predecessors
generatePredecessorsList() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Generate a list of predecessors for all HSDF actors
generatePrimeVariableCalculation() - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Generate SMT constraints for Prime Variable Calculations
generateProcessorConstraint(int) - Method in interface exploration.interfaces.oneDim.ProcessorConstraints
Set an upper bound on number of processors to be used in the schedule.
generateProcessorConstraint(int) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
 
generateProcessorConstraint(int) - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
 
generateProcessorConstraint(int) - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
 
generateProcessorSymmetryDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Generate definition for processor symmetry variables.
generateProcessorSymmetryDefinitions() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
generateProcessorSymmetryDefinitions() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate Processor symmetry definitions
generateProcessorSymmetryDefinitions() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Generate SMT variables for processor symmetry
generateProcessorSymmetryDefinitions() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Generate definitions for processor symmetry
generateProcOptimalSched(HashMap<String, String>, HashMap<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined.OptimizeSchedule
Generate constraints for improving the processor usage and solve it.
generateProcSchedule(Document, int, List<Map.Entry<String, Integer>>, Element) - Method in class platform.kalray.scheduleXML.PipelinedScheduleXml
Generate Processor schedule information.
generateProcSchedule(Document, int, List<Map.Entry<String, Integer>>, Element) - Method in class platform.tilera.scheduleXML.PipelinedScheduleXml
Generate Processor schedule information.
generateSatCode(String) - Method in class solver.Z3Solver
Generate a Z3 file with all the constraints in it.
generateSchedule(int) - Method in class graphanalysis.scheduling.ListScheduling
Generate a schedule using list scheduling for fixed number of processors
generateSchedule() - Method in class underDevelopment.QuasiStaticScheduling
 
generateScheduleApgan(Graph) - Method in class graphanalysis.scheduling.Apgan
Generate Single appearance schedule using APGAN algorithm.
generateScheduleXML - Static variable in class experiments.sharedMemory.threeDimension.LatProcBuffExploration
If true, the after exploration it will generate schedule XML files for every Pareto Point.
generateScheduleXML - Static variable in class experiments.sharedMemory.twoDimension.LatProcExploration
If true, the after exploration it will generate schedule XML files for every Pareto Point.
generateScheduleXml(Graph, Solutions, List<Map<String, String>>, CommandLineArgs) - Static method in class experiments.sharedMemory.twoDimension.PeriodProcExploration
Generate a schedule XML for Tilera platform
GenerateSdfXml - Class in output
Generates an application XML file from the Graph object.
GenerateSdfXml() - Constructor for class output.GenerateSdfXml
 
generateSolutionXml(String, Graph, Solutions, Platform, DesignFlowSolution) - Method in class platform.kalray.scheduleXML.NonPipelinedScheduleXml
Generate Schedule XML for application schedule to execute on the platform.
generateSolutionXml(String, Graph, Solutions, Map<String, String>) - Method in class platform.kalray.scheduleXML.PipelinedScheduleXml
Generate pipelined schedule XML for the platform.
generateSolutionXml(String, Graph, Solutions, Map<String, String>) - Method in class platform.tilera.scheduleXML.NonPipelinedScheduleXml
Generate Schedule XML for application schedule to execute on the platform.
generateSolutionXml(String, Graph, Solutions, Map<String, String>) - Method in class platform.tilera.scheduleXML.PipelinedScheduleXml
Generate pipelined schedule XML for the platform.
generateSubGraphDotFiles - Variable in class graphanalysis.scheduling.Apgan
Generate Dot files at every stage
generateTypeIConstraints(Map<String, Integer>) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling.TypeConstraints
Generate Type I mutual exclusion constraints.
generateTypeII_1Constraint(Map<String, Integer>) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling.TypeConstraints
For Type II tasks there are two different constraints needed.
generateTypeII_2Constraint(Map<String, Integer>) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling.TypeConstraints
For Type II tasks there are two different constraints needed.
generateUniqueTasksAndProcs() - Method in class output.GanttChart
Generate unique tasks and processors from the records
generateWorkImbalanceConstraint(int) - Method in interface exploration.interfaces.oneDim.WorkloadImbalanceConstraints
Set an upper bound on max workload imbalance between the clusters.
generateWorkImbalanceConstraint(int) - Method in class solver.distributedMemory.mapping.MappingCommSolver
 
generateWorkImbalanceConstraint(int) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
generateWorkImbalanceConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
generateWorkImbalanceConstraint(int) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
genereteGnuConfigFile(String, int) - Method in class output.GanttChart
Method to generate GNU plot file.
GenericPartitionSolver - Class in solver.distributedMemory.partitioning
Generic partition solve which finds a solution with workload assigned to a group, communication cost between the groups and number of groups.
GenericPartitionSolver(Graph, Graph, Solutions, Platform) - Constructor for class solver.distributedMemory.partitioning.GenericPartitionSolver
Initialize a generic partition solver object
GenericPlacementSolver - Class in solver.distributedMemory.placement
Generic placement solver which maps a group of SDF actors to a cluster on target platform.
GenericPlacementSolver(DesignFlowSolution.Partition, Platform) - Constructor for class solver.distributedMemory.placement.GenericPlacementSolver
Build a placement solver.
get(int) - Method in class exploration.paretoExploration.distanceexploration.Point
 
get(int) - Method in class exploration.paretoExploration.gridexploration.Point
Gets value at the specified dimension.
get(LeftEdgeModelToSchedule.Proc) - Method in class graphanalysis.scheduling.LeftEdgeModelToSchedule.OccupancyVector
 
get_latency(LeftEdgeModelToSchedule.Model) - Static method in class graphanalysis.scheduling.LeftEdgeModelToSchedule
 
getActor() - Method in class spdfcore.Channel.Link
 
getActor(String) - Method in class spdfcore.Graph
get actor with given name.
getActorAllocatedCluster(String) - Method in class solver.distributedMemory.constraints.SchedulingConstraints
Get a cluster to which an actor is allocated.
getActorList() - Method in class spdfcore.Graph
Get a list of all the actors in the graph.
getActorName() - Method in class spdfcore.PortRef
Get name of the actor to which the port belongs to.
getActors() - Method in class spdfcore.Graph
Get an iterator to all the actors in the graph
getActors(String) - Method in class spdfcore.Graph
Get actors corresponding to a specific function
getActorsAllocatedToCluster(Cluster) - Method in class solver.distributedMemory.constraints.SchedulingConstraints
Get all the actors which are allocated to the cluster.
getActorsAllocatedToDmaOfCluster(Cluster) - Method in class solver.distributedMemory.constraints.SchedulingConstraints
Get all the actors allocated to the DMA of a cluster.
getActorsBelongToK(Graph, Map<String, String>, int, int, boolean) - Method in class platform.kalray.scheduleXML.PipelinedScheduleXml
 
getActorsBelongToK(Graph, Map<String, String>, int, int, boolean) - Method in class platform.tilera.scheduleXML.PipelinedScheduleXml
 
getActorSchedule(Actor) - Method in class underDevelopment.QuasiStaticScheduling
 
getActorsMappedToCluster() - Method in class solver.distributedMemory.constraints.SchedulingConstraints
Get a map of actors mapped to all the cluster.
getActorsMappedToDmaOfCluster(Cluster) - Method in class solver.distributedMemory.constraints.SchedulingConstraints
Get all the actors which are allocated to the DMAs of the cluster.
getActorsMappedToDmaOfCluster() - Method in class solver.distributedMemory.constraints.SchedulingConstraints
Get a map of actors mapped to DMA of the cluster.
getActorType() - Method in class spdfcore.Actor
Get Actor type.
getAdjacentActors(Actor, boolean) - Method in class graphanalysis.DepthFirstSearch
The function returns a list with actors directly reachable from actor a (in case transpose if false).
getAdjacentList(Actor, List<Actor>) - Method in class graphanalysis.GraphFindCycles
Get adjacent actors to an actor
getAllChannels() - Method in class spdfcore.Actor
Gets a set of all incoming and outgoing channels connected to this actor.
getAllClusters() - Method in class platform.model.Platform
Gets all the clusters of the platform
getAllLinks() - Method in class spdfcore.Actor
Gets a set of all incoming and outgoing links connected to this actor.
getAllocatedCluster(String) - Method in class designflow.DesignFlowSolution.Schedule
Get cluster to which an actor is allocated to.
getAllocatedProcessor(String, int) - Method in class designflow.DesignFlowSolution.Schedule
Get processor to which an actor instance is allocated to.
getAlpha(Channel) - Method in class graphanalysis.properties.SplitJoinGraphAnalysis
Get Alpha for Split Edges or 1/alpha for Join Edges.
getArbitraryActor(Graph) - Method in class spdfcore.stanalys.Solutions
pick up the first actor we can get
getAutoFlag() - Method in class spdfcore.Actor
get the status of auto flag, indicating purely analytical actors
getAutoFlag() - Method in class spdfcore.Channel
get the status of auto flag, indicating purely analytical channels
getB() - Method in class exploration.paretoExploration.distanceexploration.Knee
 
getBfsActorList() - Method in class graphanalysis.BreadthFirstSearch
Gets a list of actors which if we sequentially access then we are essentially accessing them in breadth first fashion.
getBufDeclId() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Get SMT variable for buffer usage calculation of the application
getBufDeclId() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get SMT variable for total buffer size of the schedule
getBufferConstraintSdf(HashMap<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined.OptimizeSchedule
Generate a SDF graph from the model containing buffer size.
getBufferSize(Channel) - Method in class designflow.DesignFlowSolution.Schedule
Get buffer size calculated for a channel.
getChannel() - Method in class spdfcore.Channel.Link
 
getChannel(Actor, Actor) - Method in class spdfcore.Graph
Get all the channels connecting two actors
getChannel(String) - Method in class spdfcore.Graph
Get a channel with a given name.
getChannel(Actor, Actor) - Method in class underDevelopment.QuasiStaticScheduling
 
getChannelConnectingActors(Actor, Actor, Port.DIR) - Method in class graphanalysis.properties.GraphAnalysis
Get channel connecting two actors in a given direction
getChannelList() - Method in class spdfcore.Graph
Get list of all the channels in the graph.
getChannels(Port.DIR) - Method in class spdfcore.Actor
Get channels at the ports of this actor in a given direction.
getChannels() - Method in class spdfcore.Graph
Get an iterator to all the channels in the graph.
getCluster() - Method in class platform.model.DmaEngine
Gets Cluster to which the DMA Engine belongs to.
getCluster(int) - Method in class platform.model.Platform
Gets a cluster at particular index.
getCluster(String) - Method in class platform.model.Platform
Gets a cluster by its name.
getCluster() - Method in class platform.model.Processor
Gets the cluster to which this processor belongs to.
getClusterAllocatedToGroup(int) - Method in class designflow.DesignFlowSolution.Mapping
Get the cluster allocated to a group.
getClusterGroupAllocationId(int) - Method in class solver.distributedMemory.placement.GenericPlacementSolver
Get SMT variable for group to cluster allocation for a given group.
getClusterIndex(Cluster) - Method in class platform.model.Platform
Gets index of Cluster in the platform.
getCommunicationCost(Map<String, String>) - Method in interface exploration.interfaces.oneDim.CommunicationCostConstraints
Get the communication cost calculated in the model.
getCommunicationCost(Map<String, String>) - Method in class solver.distributedMemory.mapping.MappingCommSolver
 
getCommunicationCost(Map<String, String>) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
getCommunicationCost(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
getCommunicationCost(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
getCommunicationCost(Map<String, String>) - Method in class solver.distributedMemory.placement.GenericPlacementSolver
 
getConstraintName(int) - Method in class exploration.ExplorationParameters
Gets the name of the constraint for a dimension.
getCoordinates() - Method in class exploration.paretoExploration.distanceexploration.Point
 
getCoordinates() - Method in class exploration.paretoExploration.gridexploration.Point
Get co-ordinates of the point.
getCostsFromModel() - Method in class exploration.ExplorationParameters
If the query was SAT, then this method will be called to get the costs from the model given by the solver.
getCostsFromModel() - Method in class exploration.parameters.oneDimension.CommCostParams
 
getCostsFromModel() - Method in class exploration.parameters.oneDimension.LatencyParams
 
getCostsFromModel() - Method in class exploration.parameters.oneDimension.PeriodParams
 
getCostsFromModel() - Method in class exploration.parameters.oneDimension.PeriodUnfoldingParams
 
getCostsFromModel() - Method in class exploration.parameters.threeDimension.LatProcBuffParams
 
getCostsFromModel() - Method in class exploration.parameters.threeDimension.MaxwrkloadCommClusterParams
 
getCostsFromModel() - Method in class exploration.parameters.threeDimension.WrkldImbalCommClusterParams
 
getCostsFromModel() - Method in class exploration.parameters.twoDimension.LatBuffParams
 
getCostsFromModel() - Method in class exploration.parameters.twoDimension.LatProcParams
 
getCostsFromModel() - Method in class exploration.parameters.twoDimension.PeriodProcParams
 
getCostsFromModel() - Method in class exploration.parameters.twoDimension.PeriodProcUnfolding
 
getCostsFromModel() - Method in class exploration.parameters.twoDimension.WrkLoadCommCostParams
 
getCycle() - Method in class spdfcore.stanalys.InconsistencyProof
a undirected cycle found by findBadCycle in "IN-to-OUT" direction of a (rather arbitrary) 'reference channel'
getData() - Method in class graphanalysis.scheduling.Schedule.Node
 
getDenominator() - Method in class spdfcore.stanalys.Fraction
Get the denominator
getDescendant(int) - Method in class exploration.paretoExploration.distanceexploration.Knee
 
getDestinationCluster() - Method in class platform.model.NetworkLink
Gets the destination cluster of the network link.
getDestinationPort() - Method in class platform.model.NetworkLink
Gets the destination port of the network link
getDestinationProcessor() - Method in class platform.model.NetworkLink
Gets the destination processor of the network link.
getDfsPaths(Actor, Actor) - Method in class graphanalysis.DepthFirstSearch
Get depth first search path.
getDimensions() - Method in class exploration.ExplorationParameters
Gets number of dimensions in the exploration.
getDir() - Method in class spdfcore.Port
Get port direction.
getDistanceMap() - Method in class platform.model.Platform
Gets the minimum distances between the processors or clusters.
getDivisors() - Method in class spdfcore.stanalys.Expression
 
getDivisorSet(int) - Static method in class spdfcore.stanalys.PrimeDivisorSet
 
getDmaEngine(int) - Method in class platform.model.Cluster
Gets DMA inside cluster at index
getDmaEngine(int) - Method in class platform.model.Platform
Gets a DMA Engine at particular index.
getDmaEngine(Cluster) - Method in class platform.model.Platform
Gets all the DMA Engines that belong to a cluster.
getDmaEngineIndex(DmaEngine) - Method in class platform.model.Platform
Gets index of DMA Engine in the platform.
getDmaSetupTime() - Method in class platform.model.Platform
Gets the dma initialization time in the platform.
getDotDataInString(Graph) - Method in class output.DotGraph
This function return a string which contains the code for the DOT file.
getEdgeType(Channel) - Method in class graphanalysis.properties.SplitJoinGraphAnalysis
Get type of edge
getEndActor() - Method in class graphanalysis.properties.SplitJoinGraphAnalysis
Get an actor with no successors.
getEnvironmentParameters() - Method in class spdfcore.stanalys.ParamComm
Environment parameters are those that are not modified by an actor.
getExecTime - Variable in class input.ParseProfileInfo
Whether to use MIN, MAX or MEAN execution time of the actors.
getExecTime() - Method in class spdfcore.Actor
Gets execution time of the actor.
getExplorationGranularity(int) - Method in class exploration.ExplorationParameters
Gets the exploration granularity for a dimension.
getFunc() - Method in class spdfcore.Id
return the function (i.e.
getG() - Method in class exploration.paretoExploration.distanceexploration.Knee
 
getGraph() - Method in class spdfcore.Channel
 
getGraph() - Method in class spdfcore.Id
 
getGraphAppName() - Method in class spdfcore.Graph
 
getH(int) - Method in class exploration.paretoExploration.distanceexploration.Knee
 
getHsdfToSdfActor(Actor) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get HSDF to corresponding SDF actor
getId() - Method in class platform.model.PlatformComponentProp
Gets the Id of the Component.
getImmediatelyConnectedActors(Actor, Port.DIR) - Method in class graphanalysis.properties.GraphAnalysis
Get actors which are immediately connected.
getImmediatelyConnectedActors(Actor) - Method in class graphanalysis.properties.GraphAnalysis
Get actors which are immediately connected, both at input and output ports.
getIncomingChannels(Actor) - Method in class graphanalysis.properties.GraphAnalysis
Get list of all the channels connected at all input ports of an actor
getInitialTokens() - Method in class spdfcore.Channel
Get Initial tokens
getInstanceId(Actor) - Method in class graphanalysis.properties.GraphAnalysis
Get Instance Id of an HSDF actor
getIntegerCoordinates() - Method in class exploration.paretoExploration.distanceexploration.Point
 
getIntegerCoordinates() - Method in class exploration.paretoExploration.gridexploration.Point
Get integer values of the co-ordinates
getIterator() - Method in class spdfcore.stanalys.DivisorSet
 
getKmaxDeclId() - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Get SMT variable for kMax of the schedule.
getLastActors() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get list of actors without any successors.
getLastDmaPort(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Get the last DMA port of the actor when sorted by name.
getLastDmaPort(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getLatency(Map<String, String>) - Method in interface exploration.interfaces.oneDim.LatencyConstraints
Get the latency of the application graph calculated by the solver and returned in the model.
getLatency() - Method in class platform.model.Memory
Gets the latency of the memory access.
getLatency() - Method in class platform.model.NetworkLink
Gets the latency of the network link.
getLatency(Map<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
 
getLatency(Map<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getLatency(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
 
getLatency(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
 
getLatency(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MutExNonPipelinedScheduling
 
getLatency(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
 
getLatencyDeclId() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Get SMT variable for latency calculation of the application.
getLatencyDeclId() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getLatencyDeclId() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get SMT variable for latency of the schedule.
getLatencyDeclId() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Get SMT variable for latency calculation of the schedule.
getLatencyDeclId() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Get the SMT variable for latency calculation of the schedule
getLeastSatPoint() - Method in class exploration.oneDimensionExploration.BinarySearchOneDim
Get the minimum value of SAT point that was found during exploration.
getLeastSatPointModel() - Method in class exploration.oneDimensionExploration.BinarySearchOneDim
Gets model of the minimum SAT value found during exploration.
getLeft() - Method in class graphanalysis.scheduling.Schedule.Node
 
getLink(int) - Method in class platform.model.Cluster
Gets Link of cluster at index
getLink(int) - Method in class platform.model.Platform
Gets a Network Link at particular index.
getLink(int) - Method in class platform.model.Processor
Gets the network link at a particular index.
getLink(Port.DIR) - Method in class spdfcore.Channel
Get one of the two links of the channel.
getLinks(Port.DIR) - Method in class spdfcore.Actor
Get links at the ports of this actor in a given direction.
getLongestDelay() - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
This function calculates the longest path in the graph from source to destination actor.
getLowerBounds() - Method in class exploration.ExplorationParameters
Get all lower bounds.
getMapping() - Method in class designflow.DesignFlowSolution
Get mapping solution.
getMapping(LeftEdgeModelToSchedule.IterTask) - Method in class graphanalysis.scheduling.LeftEdgeModelToSchedule.UnfoldModel
 
getMaxDistanceFromSrc(Actor) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get maximum distance of an actor from source (or start actor) of the graph
getMaxDistanceInPlatform() - Method in class platform.model.Platform
Maximum distance in the platform between two processors / clusters.
getMaxDmaEnginesUsed(Cluster, String) - Method in class designflow.DesignFlowSolution.Schedule
Get total number of DMA engines used by producers or consumers of channel.
getMaxFunctionDeclId() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Get the max function.
getMaxWorkLoadPerCluster(Map<String, String>) - Method in interface exploration.interfaces.oneDim.MaxWorkLoadPerCluster
Get maximum workload per cluster from the solver model.
getMaxWorkLoadPerCluster(Map<String, String>) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
getMaxWorkLoadPerCluster(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
getMaxWorkLoadPerCluster(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
getMemory(int) - Method in class platform.model.Cluster
Gets Memory inside cluster at index
getMemory(int) - Method in class platform.model.Processor
Gets the memory at a particular index.
getMinDistance(Cluster, Cluster) - Method in class platform.model.Platform
Gets minimum distance between any two given clusters.
getMinDistance(int, int) - Method in class platform.model.Platform
Get the minimum distance in the array.
getMinDistance(Processor, Processor) - Method in class platform.model.Platform
Gets minimum distance between any two given processors.
getMinDistanceInPlatform() - Method in class platform.model.Platform
Minimum distance in the platform between two processors / clusters.
getMinimalPrimeDivisor(int) - Static method in class spdfcore.stanalys.PrimeDivisorSet
 
getMinStartTime(Actor) - Method in class graphanalysis.scheduling.ListScheduling
Depending on when the predecessors end, calculate the start time for the actor.
getModel() - Method in interface exploration.interfaces.SolverFunctions
Get model from the Solver
getModel() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
 
getModel(Solver) - Method in class solver.Z3Context
Get a Model after we have a SAT answer.
getModel() - Method in class solver.Z3Solver
 
getModelFromSolver() - Method in class exploration.ExplorationParameters
Get model of a SAT point from the solver.
getModelFromSolver() - Method in class exploration.parameters.oneDimension.CommCostParams
 
getModelFromSolver() - Method in class exploration.parameters.oneDimension.LatencyParams
 
getModelFromSolver() - Method in class exploration.parameters.oneDimension.PeriodParams
 
getModelFromSolver() - Method in class exploration.parameters.oneDimension.PeriodUnfoldingParams
 
getModelFromSolver() - Method in class exploration.parameters.threeDimension.LatProcBuffParams
 
getModelFromSolver() - Method in class exploration.parameters.threeDimension.MaxwrkloadCommClusterParams
 
getModelFromSolver() - Method in class exploration.parameters.threeDimension.WrkldImbalCommClusterParams
 
getModelFromSolver() - Method in class exploration.parameters.twoDimension.LatBuffParams
 
getModelFromSolver() - Method in class exploration.parameters.twoDimension.LatProcParams
 
getModelFromSolver() - Method in class exploration.parameters.twoDimension.PeriodProcParams
 
getModelFromSolver() - Method in class exploration.parameters.twoDimension.PeriodProcUnfolding
 
getModelFromSolver() - Method in class exploration.parameters.twoDimension.WrkLoadCommCostParams
 
getModifiedParameters() - Method in class spdfcore.stanalys.ParamComm
get all the modified parameters
getModifiedParameterSet(Actor) - Method in class spdfcore.stanalys.ParamComm
get the parameters modified by the given actor
getModifier(String) - Method in class spdfcore.Graph
Get a modifier by parameter name
getModifiers() - Method in class spdfcore.Graph
Get an iterator to all the modifiers in the graph.
getName() - Method in class platform.model.PlatformComponentProp
Gets the name of the Component.
getName() - Method in class spdfcore.Channel
Get the name of the channel
getName() - Method in class spdfcore.Id
return the name of the port/actor/modified parameter
getNonAppGraphActors() - Method in class designflow.DesignFlowSolution.Schedule
Get a list of actors which do not belong to application graph and mapped on processors.
getNumClusters() - Method in class platform.model.Platform
Gets the number of clusters in the platform.
getNumDmaEngines() - Method in class platform.model.Platform
Gets the number of DMA Engines in the platform.
getNumDmaInCluster() - Method in class platform.model.Cluster
Gets number of DMA in the cluster
getNumerator() - Method in class spdfcore.stanalys.Fraction
Get the numerator
getNumGroups() - Method in class designflow.DesignFlowSolution.Partition
Get the total number of groups.
getNumLinks() - Method in class platform.model.Platform
Gets the number of Network Links in the platform.
getNumLinks() - Method in class platform.model.Processor
Gets number of links connected to the processor
getNumLinksToCluster() - Method in class platform.model.Cluster
Gets number of links connected to the cluster
getNumMemories() - Method in class platform.model.Platform
Gets the number of memories in the platform.
getNumMemoriesInCluster() - Method in class platform.model.Cluster
Gets number of Memories in the cluster
getnumMemory() - Method in class platform.model.Processor
Gets number of memories accessed by the processor
getNumProcessors() - Method in class platform.model.Platform
Gets the number of processors in the platform.
getNumProcInCluster() - Method in class platform.model.Cluster
Gets number of processors in the cluster
getOpposite(Actor) - Method in class spdfcore.Channel
Get the link at the opposite side of the channel
getOpposite() - Method in class spdfcore.Channel.Link
 
getOpposite() - Method in enum spdfcore.Port.DIR
 
getOutgoingPreviousDmaActor(Actor, Graph) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined.OptimizeSchedule
 
getOutToInRatio() - Method in class spdfcore.stanalys.InconsistencyProof
mismathed factors in the cycle: "OUT" to "IN" ratio of a (rather arbitrary) 'reference channel'
getOverlappingActors(String, List<String>, HashMap<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined.OptimizeSchedule
Get actors which can potentially execute in parallel with this actor.
getParameter() - Method in class spdfcore.Modifier
Get Parameter
getParameterSet() - Method in class spdfcore.stanalys.Expression
Get the set of all parameters used in the expression.
getParameterType() - Method in class spdfcore.Modifier
Get type of the parameter
getParetoModels() - Method in class exploration.paretoExploration.gridexploration.GridBasedExploration
Get list of model for each Pareto point found in exploration.
getParetoPoints() - Method in class exploration.paretoExploration.gridexploration.GridBasedExploration
Get all the Pareto points found from this exploration.
getPartition() - Method in class designflow.DesignFlowSolution
Get partitioning solution.
getpartitionAwareGraph() - Method in class designflow.DesignFlowSolution
Get partition aware graph in SDF
getpartitionAwareGraphActor(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getPartitionAwareGraphSolutions() - Method in class designflow.DesignFlowSolution
Get solutions to partition aware graph
getPartitionAwareHsdf() - Method in class designflow.DesignFlowSolution
Get HSDF equivalent of partition aware graph
getPath(Actor, Actor) - Method in class graphanalysis.BellmanFord
Get the path between two actors.
getPath(Actor, Actor) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get multiple paths between two actors
getPeriod(Map<String, String>) - Method in interface exploration.interfaces.oneDim.PeriodConstraints
Get the period value calculated by the solver on a SAT result.
getPeriod() - Method in class graphanalysis.scheduling.LeftEdgeModelToSchedule.UnfoldModel
 
getPeriod(Map<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getPeriod(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
 
getPeriod(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
 
getPeriod() - Method in class spdfcore.Modifier
Get period
getPeriodActor(String) - Method in class spdfcore.stanalys.ParamComm
get period actor for the parameter.
getPeriodDeclId() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getPeriodDeclId() - Method in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Get SMT variable for period of the schedule.
getPeriodDeclId() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Get the SMT variable for period calculation of the schedule
getPort() - Method in class spdfcore.Channel.Link
 
getPort(Id) - Method in class spdfcore.Graph
get port with given name and function Port must exist!
getPortName() - Method in class spdfcore.PortRef
Get name of the port
getPorts() - Method in class spdfcore.Graph
Get an iterator to all the ports in the graph.
getPower(int) - Method in class spdfcore.stanalys.DivisorSet
 
getPower(String) - Method in class spdfcore.stanalys.DivisorSet
 
getPredecessors(Actor) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get all the predecessors which do not have any initial tokens on the channels connecting to it.
getPrimeNumber() - Method in class graphanalysis.scheduling.Schedule
 
getProcDeclId() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get SMT variable for total processors used in the schedule
getProcDeclId() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Get SMT variable for number of processors used in the schedule.
getProcDeclId() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Get the SMT variable for total processors used in the schedule
getProcessor(int) - Method in class platform.model.Cluster
Gets processor inside cluster at index
getProcessor(int) - Method in class platform.model.Platform
Gets a processor at particular index.
getProcessor(String) - Method in class platform.model.Platform
Get a processor by its name.
getProcessors(Map<String, String>) - Method in interface exploration.interfaces.oneDim.ProcessorConstraints
Get the number of processors used in the schedule represented in the model.
getProcessors(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
 
getProcessors(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
 
getProcessors(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
 
getProcIndex(Processor) - Method in class platform.model.Platform
Gets index of Processor in the platform.
getProp(Id.PROP) - Method in class spdfcore.Id
 
getR() - Method in class exploration.paretoExploration.distanceexploration.Knee
 
getRate() - Method in class spdfcore.Port
Get rate of the port.
getRate(Port) - Method in class spdfcore.stanalys.GraphExpressions
Get the rate of a port as a parsed expression.
getRepetitionCount(Graph) - Method in class graphanalysis.scheduling.Apgan
Construction repetition count for each channel.
getRight() - Method in class graphanalysis.scheduling.Schedule.Node
 
getSatPoints() - Method in class exploration.oneDimensionExploration.BinarySearchOneDim
Get List of SAT points
getSatPoints() - Method in class exploration.paretoExploration.gridexploration.GridBasedExploration
Get list of all the SAT points found during the exploration.
getSchedMatrixDeclId() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Get SMT variable for the schedule matrix.
getSchedule() - Method in class designflow.DesignFlowSolution
Get schedule from the design flow.
getScheduleForProcSortedWithXprime(Map<String, String>, int) - Method in class platform.kalray.scheduleXML.PipelinedScheduleXml
 
getScheduleForProcSortedWithXprime(Map<String, String>, int) - Method in class platform.tilera.scheduleXML.PipelinedScheduleXml
 
getSchedulingConstraints() - Method in class designflow.DesignFlowSolution.Mapping
Get all the scheduling constraints based on mapping.
getSdfToAllHsdfActors(Actor) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get HSDF actors corresponding to an SDF actor
getSdfToHsdfActor(Actor, int) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get an HSDF actor from SDF actor and instance id
getSdfToHsdfChannels(Channel) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get all HSDF channels corresponding to SDF channel.
getSdfToHsdfChannels(Actor, Actor) - Method in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Get all HSDF channels corresponding to SDF channel.
getSizeInBytes() - Method in class platform.model.Memory
Gets the size of the memory in bytes.
getSolution(Actor) - Method in class spdfcore.stanalys.Solutions
Gets an expression to solution of an actor
getSolutions() - Method in class spdfcore.stanalys.SpdfAnalyzer
 
getSort(String) - Method in class solver.Z3Solver
Get a Sort from the Z3.
getSortedActorInstances(DmaEngine) - Method in class designflow.DesignFlowSolution.Schedule
Get a list of actors allocated to DMA engine sorted by their start times.
getSortedActorInstances(Processor) - Method in class designflow.DesignFlowSolution.Schedule
Get a list of actors allocated to processor sorted by their start times.
getSortedDmaPortList(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
We sort the ports of an actor by their names.
getSortedDmaPortList(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getSortedPortList(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
We sort the ports of an actor by their names.
getSortedPortList(Actor) - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
getSortedTasksForPeriod(int) - Method in class graphanalysis.scheduling.LeftEdgeModelToSchedule.UnfoldModel
 
getSourceCluster() - Method in class platform.model.NetworkLink
Gets the source cluster of the network link.
getSourcePort() - Method in class platform.model.NetworkLink
Gets the source port of the network link
getSourceProcessor() - Method in class platform.model.NetworkLink
Gets the source processor of the network link.
getSpeed() - Method in class platform.model.Cluster
Get Speed of the cluster
getSpeed() - Method in class platform.model.Processor
Gets the speed of the processor
getStartActor() - Method in class graphanalysis.properties.SplitJoinGraphAnalysis
Get an actor with no predecessors
getStartActor(Graph) - Method in class underDevelopment.QuasiStaticScheduling
 
getStartActors() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get list of actors without any predecessors.
getStatistics() - Method in class solver.Z3Solver
Get Z3 Solver statistics
getStringSchedule() - Method in class graphanalysis.scheduling.Apgan
Get APGAN schedule.
getStringSchedule() - Method in class underDevelopment.QuasiStaticScheduling
 
getStronglyConnectedComponents() - Method in class graphanalysis.Kosaraju
Get list of strongly connected components
getSuccessors(Actor) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Get all the successors which do not have any initial tokens on the channels connecting to it.
getTimedoutPoints() - Method in class exploration.oneDimensionExploration.BinarySearchOneDim
Get List of TIMED OUT points
getTimeIncrement(int, int) - Method in class graphanalysis.scheduling.ListScheduling
Function to increment the time of the processor in case there is no ready actor.
getTokenSize() - Method in class spdfcore.Channel
Get size of the tokens
getTotalBufferSize(Map<String, String>) - Method in interface exploration.interfaces.oneDim.BufferConstraints
Get Total Buffer Size from the model.
getTotalBufferSize(Map<String, String>) - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
 
getTotalBufferSize(Map<String, String>) - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
 
getTotalClustersUsed(Map<String, String>) - Method in interface exploration.interfaces.oneDim.ClusterConstraints
Get total number of clusters used from the model.
getTotalClustersUsed(Map<String, String>) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
getTotalClustersUsed(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
getTotalClustersUsed(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
getTotalCommunicationCost() - Method in class designflow.DesignFlowSolution.Partition
Get the total communication cost.
getTotalProc() - Method in class graphanalysis.scheduling.LeftEdgeModelToSchedule.OccupancyVector
 
getTrueBounds(Point) - Method in class exploration.paretoExploration.gridexploration.GridBasedExploration
Get bounds according to the unknown area where we should perform the binary search exploration.
getUnsatGen(int) - Method in class exploration.paretoExploration.distanceexploration.Knee
 
getUnsatPoints() - Method in class exploration.oneDimensionExploration.BinarySearchOneDim
Get List of UNSAT points
getUpperBounds() - Method in class exploration.ExplorationParameters
Get all upper bounds.
getUsedParameterSet(Actor) - Method in class spdfcore.stanalys.ParamComm
get the set of parameters used by the actor by convention, a parameter modified by an actor can be also a parameter used, we do not exclude the parameters modified from the set of parameter used.
getUserSet(String) - Method in class spdfcore.stanalys.ParamComm
get the user actors for the parameter.
getVersion() - Method in class solver.Z3Context
Get Version of the Z3 Solver.
getWorkLoadImbalance(Map<String, String>) - Method in interface exploration.interfaces.oneDim.WorkloadImbalanceConstraints
 
getWorkLoadImbalance(Map<String, String>) - Method in class solver.distributedMemory.mapping.MappingCommSolver
 
getWorkLoadImbalance(Map<String, String>) - Method in class solver.distributedMemory.partitioning.GenericPartitionSolver
 
getWorkLoadImbalance(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverHSDF
 
getWorkLoadImbalance(Map<String, String>) - Method in class solver.distributedMemory.partitioning.PartitionSolverSDF
 
glbClk - Variable in class graphanalysis.throughput.Throughput.TransitionSystem.State
 
globalSolutions - Variable in class graphanalysis.throughput.Throughput
Solutions of graph.
graph - Variable in class designflow.DesignFlowSolution
Application Graph SDF
graph - Variable in class designflow.NonPipelinedScheduling
Application Graph SDF
graph - Variable in class designflow.PipelinedScheduling
Application Graph SDF
graph - Variable in class graphanalysis.BellmanFord
Graph under analysis
graph - Variable in class graphanalysis.BreadthFirstSearch
Graph to be traversed.
graph - Variable in class graphanalysis.CalculateBounds
Graph to be analysed
graph - Variable in class graphanalysis.properties.GraphAnalysisSdfAndHsdf
SDF Graph
graph - Variable in class graphanalysis.throughput.Throughput.TransitionSystem
 
graph - Variable in class input.ParseProfileInfo
Application graph
graph - Variable in class solver.distributedMemory.mapping.MappingCommSolver
Application Graph
graph - Variable in class solver.distributedMemory.partitioning.GenericPartitionSolver
Application Graph
graph - Variable in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Application Graph
graph - Variable in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
graph - Variable in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Application SDF graph
graph - Variable in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Application graph.
graph - Variable in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Application SDF graph
graph - Variable in class spdfcore.Channel
 
Graph - Class in spdfcore
A Graph is a collection of actors which are connected by channels.
Graph() - Constructor for class spdfcore.Graph
 
Graph(Graph) - Constructor for class spdfcore.Graph
Build a graph as exactly a copy of another graph.
graph - Variable in class spdfcore.Id
 
graph - Variable in class spdfcore.stanalys.ParamComm
 
graph - Variable in class spdfcore.stanalys.Solutions.Data
 
graph - Variable in class spdfcore.stanalys.SpdfAnalyzer
 
graph - Variable in class tests.TryLiveness
 
graph - Variable in class tests.TrySafety
 
graph - Variable in class underDevelopment.QuasiStaticScheduling
 
graph - Variable in class underDevelopment.TryQuasiStatic
 
graphanalysis - package graphanalysis
package contains algorithms to perform different analysis on the Application graph.
graphAnalysis - Variable in class graphanalysis.DepthFirstSearch
Properties of graph.
graphAnalysis - Variable in class graphanalysis.GraphFindCycles
Graph analysis to quickly calculate some properties.
graphAnalysis - Variable in class graphanalysis.Kosaraju
Graph properties for quick reference.
GraphAnalysis - Class in graphanalysis.properties
Different methods to check certain properties of the Graph.
GraphAnalysis() - Constructor for class graphanalysis.properties.GraphAnalysis
 
graphAnalysis - Variable in class graphanalysis.throughput.ThroughputMcm
Get some properties of the graph
graphAnalysis - Variable in class solver.sharedMemory.combinedSolver.pipelined.MutExPipelinedScheduling
Graph analysis object to determine some properties of the graph
graphAnalysis - Variable in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Graph analysis object to get trivial properties
graphanalysis.properties - package graphanalysis.properties
package contains methods to analyze different properties of SDF, HSDF and Split-join graphs.
graphanalysis.scheduling - package graphanalysis.scheduling
package contains miscellaneous scheduling algorithms and some support functions for scheduling algorithms.
graphanalysis.throughput - package graphanalysis.throughput
package contains algorithms to calculate throughput of SDF graph.
GraphAnalysisSdfAndHsdf - Class in graphanalysis.properties
Different methods to check certain properties of an SDF and its equivalent HSDF graph.
GraphAnalysisSdfAndHsdf(Graph, Solutions) - Constructor for class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Initialize graph analysis object
GraphAnalysisSdfAndHsdf(Graph, Solutions, Graph) - Constructor for class graphanalysis.properties.GraphAnalysisSdfAndHsdf
Initialize graph analysis object
GraphExpressions - Class in spdfcore.stanalys
Stores the parsed expressions for the rates and periods of the given SPDF graph.
GraphExpressions() - Constructor for class spdfcore.stanalys.GraphExpressions
 
GraphFindCycles - Class in graphanalysis
Find cycles in the graph.
GraphFindCycles() - Constructor for class graphanalysis.GraphFindCycles
 
GraphFindCycles.Color - Enum in graphanalysis
Node color
GraphFindCycles.Color() - Constructor for enum graphanalysis.GraphFindCycles.Color
 
graphSolutions - Variable in class designflow.NonPipelinedScheduling
Solutions of application graph
graphSolutions - Variable in class designflow.PipelinedScheduling
Solutions of application graph
graphSymmetry - Variable in class input.CommandLineArgs
Add task symmetry constraints
graphSymmetry - Variable in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Enable Task Symmetry
graphSymmetry - Variable in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
graphSymmetry - Variable in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Enable task symmetry constraints
graphSymmetry - Variable in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Enable task symmetry
graphSymmetry - Variable in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Task Symmetry
graphSymmetryLexicographic() - Method in class solver.distributedMemory.scheduling.ClusterMutExclNonPipelined
Task Symmetry constraints
graphSymmetryLexicographic() - Method in class solver.distributedMemory.scheduling.ClusterMutExclPipelined
 
graphSymmetryLexicographic() - Method in class solver.sharedMemory.combinedSolver.MutualExclusionSolver
Generate Task symmetry constraints
graphSymmetryLexicographic() - Method in class solver.sharedMemory.combinedSolver.nonpipelined.MatrixSolver
Generate Task Symmetry constraints
graphSymmetryLexicographic() - Method in class solver.sharedMemory.combinedSolver.pipelined.UnfoldingScheduling
Generate task symmetry constraints
greaterThan(Point) - Method in class exploration.paretoExploration.distanceexploration.Point
 
greaterThan(Point) - Method in class exploration.paretoExploration.gridexploration.Point
Check if this point has co-ordinates greater than of other Point p.
greaterThanOrEquals(Point) - Method in class exploration.paretoExploration.distanceexploration.Point
 
greaterThanOrEquals(Point) - Method in class exploration.paretoExploration.gridexploration.Point
Check if this point has co-ordinates greater than or equal of other Point p.
GridBasedExploration - Class in exploration.paretoExploration.gridexploration
Grid-based Design Space Exploration of multi-dimensional design space.
GridBasedExploration(String, int, int, ExplorationParameters) - Constructor for class exploration.paretoExploration.gridexploration.GridBasedExploration
Initialize the grid-based explorer.
groupAllocated(Actor) - Method in class designflow.DesignFlowSolution.Partition
Get the group to which an actor is allocated.
groupList - Variable in class designflow.DesignFlowSolution.Partition
Map of list of actors allocated to a group.
A B C D E F G H I K L M N O P Q R S T U V W X Y Z