Uses of Class
org.apache.storm.scheduler.TopologyDetails
Package
Description
-
Uses of TopologyDetails in org.apache.storm.daemon.nimbus
ModifierConstructorDescriptionTopologyResources
(TopologyDetails td, Assignment assignment) TopologyResources
(TopologyDetails td, SchedulerAssignment assignment) -
Uses of TopologyDetails in org.apache.storm.scheduler
Modifier and TypeMethodDescriptionGet a topology given an ID.Get a topology given a topology name.Modifier and TypeMethodDescriptionTopologies.getTopologies()
Topologies.getTopologiesOwnedBy
(String user) Get all topologies submitted/owned by a given user.Topologies.iterator()
Cluster.needsSchedulingTopologies()
ISchedulingState.needsSchedulingTopologies()
Get all of the topologies that need scheduling.Modifier and TypeMethodDescriptionint
Cluster.getAssignedNumWorkers
(TopologyDetails topology) int
ISchedulingState.getAssignedNumWorkers
(TopologyDetails topology) Get the number of workers assigned to a topology.Cluster.getNeedsSchedulingComponentToExecutors
(TopologyDetails topology) ISchedulingState.getNeedsSchedulingComponentToExecutors
(TopologyDetails topology) Get the component name to executor list for executors that need to be scheduled.Cluster.getNeedsSchedulingExecutorToComponents
(TopologyDetails topology) ISchedulingState.getNeedsSchedulingExecutorToComponents
(TopologyDetails topology) Get the executor to component name map for executors that need to be scheduled.Cluster.getUnassignedExecutors
(TopologyDetails topology) ISchedulingState.getUnassignedExecutors
(TopologyDetails topology) get the unassigned executors of the topology.boolean
Cluster.needsScheduling
(TopologyDetails topology) boolean
ISchedulingState.needsScheduling
(TopologyDetails topology) Does the topology need scheduling.boolean
Cluster.needsSchedulingRas
(TopologyDetails topology) boolean
ISchedulingState.needsSchedulingRas
(TopologyDetails topology) LikeISchedulingState.needsScheduling(TopologyDetails)
but does not take into account the number of workers requested.void
Cluster.setStatus
(TopologyDetails td, String statusMessage) set scheduler status for a topology.boolean
Cluster.wouldFit
(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td, NormalizedResourceOffer resourcesAvailable, double maxHeap) boolean
ISchedulingState.wouldFit
(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td, NormalizedResourceOffer resourcesAvailable, double maxHeap) Would scheduling exec on ws fit?ModifierConstructorDescriptionTopologies
(TopologyDetails... details) Create a new Topologies from a list of TopologyDetails.ModifierConstructorDescriptionTopologies
(Map<String, TopologyDetails> topologies) Create a new Topologies from a map of id to topology. -
Uses of TopologyDetails in org.apache.storm.scheduler.multitenant
Modifier and TypeMethodDescriptionvoid
DefaultPool.addTopology
(TopologyDetails td) void
FreePool.addTopology
(TopologyDetails td) void
IsolatedPool.addTopology
(TopologyDetails td) abstract void
NodePool.addTopology
(TopologyDetails td) Add a topology to the pool.boolean
DefaultPool.canAdd
(TopologyDetails td) boolean
FreePool.canAdd
(TopologyDetails td) boolean
IsolatedPool.canAdd
(TopologyDetails td) abstract boolean
NodePool.canAdd
(TopologyDetails td) Check if this topology can be added to this pool.ModifierConstructorDescriptionRoundRobinSlotScheduler
(TopologyDetails td, int slotsToUse, Cluster cluster) Create a new scheduler for a given topology. -
Uses of TopologyDetails in org.apache.storm.scheduler.resource
Modifier and TypeMethodDescriptionUser.getNextTopologyToSchedule
(ISchedulingState cluster) User.getRunningTopologyWithLowestPriority
(ISchedulingState cluster) Modifier and TypeMethodDescriptionUser.getPendingTopologies
(ISchedulingState cluster) User.getRunningTopologies
(ISchedulingState cluster) Modifier and TypeMethodDescriptionvoid
RasNode.assign
(WorkerSlot target, TopologyDetails td, Collection<ExecutorDetails> executors) Assigns a worker to a node.void
RasNode.assignSingleExecutor
(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td) Assign a single executor to a slot, even if other things are in the slot.boolean
RasNode.couldEverFit
(ExecutorDetails exec, TopologyDetails td) Is there any possibility that exec could ever fit on this node.void
RasNode.freeSingleExecutor
(ExecutorDetails exec, TopologyDetails topo) frees a single executor.void
User.markTopoUnsuccess
(TopologyDetails topo) void
User.markTopoUnsuccess
(TopologyDetails topo, Cluster cluster, String msg) boolean
RasNode.wouldFit
(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td) Would scheduling exec in ws fit with the current resource constraints. -
Uses of TopologyDetails in org.apache.storm.scheduler.resource.strategies.priority
Modifier and TypeFieldDescriptionprotected final LinkedList<TopologyDetails>
DefaultSchedulingPriorityStrategy.SimulatedUser.tds
Modifier and TypeMethodDescriptionDefaultSchedulingPriorityStrategy.SimulatedUser.getNextHighest()
DefaultSchedulingPriorityStrategy.SimulatedUser.simScheduleNextHighest()
GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser.simScheduleNextHighest()
Modifier and TypeMethodDescriptionDefaultSchedulingPriorityStrategy.getOrderedTopologies
(ISchedulingState cluster, Map<String, User> userMap) GenericResourceAwareSchedulingPriorityStrategy.getOrderedTopologies
(ISchedulingState cluster, Map<String, User> userMap) ISchedulingPriorityStrategy.getOrderedTopologies
(ISchedulingState schedulingState, Map<String, User> userMap) Prioritize the list of all topologies in the cluster.Modifier and TypeMethodDescriptionprotected double
DefaultSchedulingPriorityStrategy.SimulatedUser.getScore
(double availableCpu, double availableMemory, TopologyDetails td) Get a score for the simulated user.protected double
GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser.getScore
(double availableCpu, double availableMemory, Map<String, Double> availableGenericResources, TopologyDetails td) Get a score for the simulated user. -
Uses of TopologyDetails in org.apache.storm.scheduler.resource.strategies.scheduling
Modifier and TypeFieldDescriptionprotected TopologyDetails
BaseResourceAwareStrategy.topologyDetails
Modifier and TypeMethodDescriptionprotected void
BaseResourceAwareStrategy.prepareForScheduling
(Cluster cluster, TopologyDetails topologyDetails) Initialize instance variables as the first step inBaseResourceAwareStrategy.schedule(Cluster, TopologyDetails)
.protected void
ConstraintSolverStrategy.prepareForScheduling
(Cluster cluster, TopologyDetails topologyDetails) BaseResourceAwareStrategy.schedule
(Cluster cluster, TopologyDetails td) Note that this method is not thread-safe.IStrategy.schedule
(Cluster schedulingState, TopologyDetails td) This method is invoked to calculate a scheduling for topology td.static boolean
ConstraintSolverStrategy.validateSolution
(Cluster cluster, TopologyDetails topo) Determines if a scheduling is valid and all constraints are satisfied (for use in testing).ModifierConstructorDescriptionSchedulingSearcherState
(Map<WorkerSlot, Map<String, Integer>> workerCompAssignmentCnts, Map<RasNode, Map<String, Integer>> nodeCompAssignmentCnts, int maxStatesSearched, long maxTimeMs, List<ExecutorDetails> execs, LinkedList<ExecutorDetails> unassignedAckers, TopologyDetails td, Map<ExecutorDetails, String> execToComp) -
Uses of TopologyDetails in org.apache.storm.scheduler.resource.strategies.scheduling.sorter
Modifier and TypeFieldDescriptionprotected TopologyDetails
ExecSorterByConnectionCount.topologyDetails
protected TopologyDetails
ExecSorterByProximity.topologyDetails
protected TopologyDetails
NodeSorter.topologyDetails
protected TopologyDetails
NodeSorterHostProximity.topologyDetails
ModifierConstructorDescriptionExecSorterByConnectionCount
(TopologyDetails topologyDetails) ExecSorterByConstraintSeverity
(Cluster cluster, TopologyDetails topologyDetails) ExecSorterByProximity
(TopologyDetails topologyDetails) NodeSorter
(Cluster cluster, TopologyDetails topologyDetails, BaseResourceAwareStrategy.NodeSortType nodeSortType) Initialize for the default implementation node sorting.NodeSorterHostProximity
(Cluster cluster, TopologyDetails topologyDetails) NodeSorterHostProximity
(Cluster cluster, TopologyDetails topologyDetails, BaseResourceAwareStrategy.NodeSortType nodeSortType) Initialize for the default implementation node sorting.