Uses of Class
org.apache.storm.scheduler.TopologyDetails
Packages that use TopologyDetails
Package
Description
- 
Uses of TopologyDetails in org.apache.storm.daemon.nimbusConstructors in org.apache.storm.daemon.nimbus with parameters of type TopologyDetailsModifierConstructorDescriptionTopologyResources(TopologyDetails td, Assignment assignment) TopologyResources(TopologyDetails td, SchedulerAssignment assignment) 
- 
Uses of TopologyDetails in org.apache.storm.schedulerMethods in org.apache.storm.scheduler that return TopologyDetailsModifier and TypeMethodDescriptionGet a topology given an ID.Get a topology given a topology name.Methods in org.apache.storm.scheduler that return types with arguments of type TopologyDetailsModifier 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.Methods in org.apache.storm.scheduler with parameters of type TopologyDetailsModifier and TypeMethodDescriptionintCluster.getAssignedNumWorkers(TopologyDetails topology) intISchedulingState.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.booleanCluster.needsScheduling(TopologyDetails topology) booleanISchedulingState.needsScheduling(TopologyDetails topology) Does the topology need scheduling.booleanCluster.needsSchedulingRas(TopologyDetails topology) booleanISchedulingState.needsSchedulingRas(TopologyDetails topology) LikeISchedulingState.needsScheduling(TopologyDetails)but does not take into account the number of workers requested.voidCluster.setStatus(TopologyDetails td, String statusMessage) set scheduler status for a topology.booleanCluster.wouldFit(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td, NormalizedResourceOffer resourcesAvailable, double maxHeap) booleanISchedulingState.wouldFit(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td, NormalizedResourceOffer resourcesAvailable, double maxHeap) Would scheduling exec on ws fit? With a heap <= maxHeap total memory added <= memoryAvailable and cpu added <= cpuAvailable.Constructors in org.apache.storm.scheduler with parameters of type TopologyDetailsModifierConstructorDescriptionTopologies(TopologyDetails... details) Create a new Topologies from a list of TopologyDetails.Constructor parameters in org.apache.storm.scheduler with type arguments of type TopologyDetailsModifierConstructorDescriptionTopologies(Map<String, TopologyDetails> topologies) Create a new Topologies from a map of id to topology.
- 
Uses of TopologyDetails in org.apache.storm.scheduler.multitenantMethods in org.apache.storm.scheduler.multitenant with parameters of type TopologyDetailsModifier and TypeMethodDescriptionvoidDefaultPool.addTopology(TopologyDetails td) voidFreePool.addTopology(TopologyDetails td) voidIsolatedPool.addTopology(TopologyDetails td) abstract voidNodePool.addTopology(TopologyDetails td) Add a topology to the pool.booleanDefaultPool.canAdd(TopologyDetails td) booleanFreePool.canAdd(TopologyDetails td) booleanIsolatedPool.canAdd(TopologyDetails td) abstract booleanNodePool.canAdd(TopologyDetails td) Check if this topology can be added to this pool.Constructors in org.apache.storm.scheduler.multitenant with parameters of type TopologyDetailsModifierConstructorDescriptionRoundRobinSlotScheduler(TopologyDetails td, int slotsToUse, Cluster cluster) Create a new scheduler for a given topology.
- 
Uses of TopologyDetails in org.apache.storm.scheduler.resourceMethods in org.apache.storm.scheduler.resource that return TopologyDetailsModifier and TypeMethodDescriptionUser.getNextTopologyToSchedule(ISchedulingState cluster) User.getRunningTopologyWithLowestPriority(ISchedulingState cluster) Methods in org.apache.storm.scheduler.resource that return types with arguments of type TopologyDetailsModifier and TypeMethodDescriptionUser.getPendingTopologies(ISchedulingState cluster) User.getRunningTopologies(ISchedulingState cluster) Methods in org.apache.storm.scheduler.resource with parameters of type TopologyDetailsModifier and TypeMethodDescriptionvoidRasNode.assign(WorkerSlot target, TopologyDetails td, Collection<ExecutorDetails> executors) Assigns a worker to a node.voidRasNode.assignSingleExecutor(WorkerSlot ws, ExecutorDetails exec, TopologyDetails td) Assign a single executor to a slot, even if other things are in the slot.booleanRasNode.couldEverFit(ExecutorDetails exec, TopologyDetails td) Is there any possibility that exec could ever fit on this node.voidRasNode.freeSingleExecutor(ExecutorDetails exec, TopologyDetails topo) frees a single executor.voidUser.markTopoUnsuccess(TopologyDetails topo) voidUser.markTopoUnsuccess(TopologyDetails topo, Cluster cluster, String msg) booleanRasNode.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.priorityFields in org.apache.storm.scheduler.resource.strategies.priority with type parameters of type TopologyDetailsModifier and TypeFieldDescriptionprotected final LinkedList<TopologyDetails>DefaultSchedulingPriorityStrategy.SimulatedUser.tdsMethods in org.apache.storm.scheduler.resource.strategies.priority that return TopologyDetailsModifier and TypeMethodDescriptionDefaultSchedulingPriorityStrategy.SimulatedUser.getNextHighest()DefaultSchedulingPriorityStrategy.SimulatedUser.simScheduleNextHighest()GenericResourceAwareSchedulingPriorityStrategy.GrasSimulatedUser.simScheduleNextHighest()Methods in org.apache.storm.scheduler.resource.strategies.priority that return types with arguments of type TopologyDetailsModifier 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.Methods in org.apache.storm.scheduler.resource.strategies.priority with parameters of type TopologyDetailsModifier and TypeMethodDescriptionprotected doubleDefaultSchedulingPriorityStrategy.SimulatedUser.getScore(double availableCpu, double availableMemory, TopologyDetails td) Get a score for the simulated user.protected doubleGenericResourceAwareSchedulingPriorityStrategy.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.schedulingFields in org.apache.storm.scheduler.resource.strategies.scheduling declared as TopologyDetailsModifier and TypeFieldDescriptionprotected TopologyDetailsBaseResourceAwareStrategy.topologyDetailsMethods in org.apache.storm.scheduler.resource.strategies.scheduling with parameters of type TopologyDetailsModifier and TypeMethodDescriptionprotected voidBaseResourceAwareStrategy.prepareForScheduling(Cluster cluster, TopologyDetails topologyDetails) Initialize instance variables as the first step inBaseResourceAwareStrategy.schedule(Cluster, TopologyDetails).protected voidConstraintSolverStrategy.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 booleanConstraintSolverStrategy.validateSolution(Cluster cluster, TopologyDetails topo) Determines if a scheduling is valid and all constraints are satisfied (for use in testing).Constructors in org.apache.storm.scheduler.resource.strategies.scheduling with parameters of type TopologyDetailsModifierConstructorDescriptionSchedulingSearcherState(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.sorterFields in org.apache.storm.scheduler.resource.strategies.scheduling.sorter declared as TopologyDetailsModifier and TypeFieldDescriptionprotected TopologyDetailsExecSorterByConnectionCount.topologyDetailsprotected TopologyDetailsExecSorterByProximity.topologyDetailsprotected TopologyDetailsNodeSorter.topologyDetailsprotected TopologyDetailsNodeSorterHostProximity.topologyDetailsConstructors in org.apache.storm.scheduler.resource.strategies.scheduling.sorter with parameters of type TopologyDetailsModifierConstructorDescriptionExecSorterByConnectionCount(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.