Uses of Class
org.apache.storm.scheduler.Cluster
Packages that use Cluster
Package
Description
- 
Uses of Cluster in org.apache.storm.schedulerSubclasses of Cluster in org.apache.storm.schedulerModifier and TypeClassDescriptionclassA Cluster that only allows modification to a single topology.Methods in org.apache.storm.scheduler with parameters of type ClusterModifier and TypeMethodDescriptionstatic voidDefaultScheduler.defaultSchedule(Topologies topologies, Cluster cluster) static Map<WorkerSlot,List<ExecutorDetails>> EvenScheduler.getAliveAssignedWorkerSlotExecutors(Cluster cluster, String topologyId) voidDefaultScheduler.schedule(Topologies topologies, Cluster cluster) voidEvenScheduler.schedule(Topologies topologies, Cluster cluster) voidIScheduler.schedule(Topologies topologies, Cluster cluster) Set assignments for the topologies which needs scheduling.voidIsolationScheduler.schedule(Topologies topologies, Cluster cluster) static voidEvenScheduler.scheduleTopologiesEvenly(Topologies topologies, Cluster cluster) static Set<WorkerSlot>DefaultScheduler.slotsCanReassign(Cluster cluster, Set<WorkerSlot> slots) voidCluster.updateFrom(Cluster other) Update the assignments and status from the other cluster.Constructors in org.apache.storm.scheduler with parameters of type ClusterModifierConstructorDescriptionCopy constructor.Cluster(Cluster src, Topologies topologies) Testing Constructor that takes an existing cluster and replaces the topologies in it.SingleTopologyCluster(Cluster other, String topologyId) Create a new cluster that only allows modifications to a single topology.
- 
Uses of Cluster in org.apache.storm.scheduler.blacklistMethods in org.apache.storm.scheduler.blacklist with parameters of type ClusterModifier and TypeMethodDescriptionvoidBlacklistScheduler.schedule(Topologies topologies, Cluster cluster) 
- 
Uses of Cluster in org.apache.storm.scheduler.blacklist.strategiesMethods in org.apache.storm.scheduler.blacklist.strategies with parameters of type ClusterModifier and TypeMethodDescriptionDefaultBlacklistStrategy.createHostToSupervisorMap(List<String> blacklistedNodeIds, Cluster cluster) DefaultBlacklistStrategy.getBlacklist(List<Map<String, Set<Integer>>> supervisorsWithFailures, List<Map<String, Integer>> sendAssignmentFailureCount, Cluster cluster, Topologies topologies) IBlacklistStrategy.getBlacklist(List<Map<String, Set<Integer>>> badSupervisorsToleranceSlidingWindow, List<Map<String, Integer>> sendAssignmentFailureCount, Cluster cluster, Topologies topologies) Get blacklist by blacklist strategy.DefaultBlacklistStrategy.releaseBlacklistWhenNeeded(Cluster cluster, List<String> blacklistedNodeIds) Decide when/if to release blacklisted hosts.RasBlacklistStrategy.releaseBlacklistWhenNeeded(Cluster cluster, List<String> blacklistedNodeIds) 
- 
Uses of Cluster in org.apache.storm.scheduler.multitenantFields in org.apache.storm.scheduler.multitenant declared as ClusterMethods in org.apache.storm.scheduler.multitenant with parameters of type ClusterModifier and TypeMethodDescriptionvoidNode.assign(String topId, Collection<ExecutorDetails> executors, Cluster cluster) Assign a free slot on the node to the following topology and executors.voidNode.free(WorkerSlot ws, Cluster cluster, boolean forceFree) Frees a single slot in this node.voidNode.freeAllSlots(Cluster cluster) Free all slots on this node.voidNode.freeTopology(String topId, Cluster cluster) Frees all the slots for a topology.Node.getAllNodesFrom(Cluster cluster) voidvoidInitialize the pool.voidMultitenantScheduler.schedule(Topologies topologies, Cluster cluster) Constructors in org.apache.storm.scheduler.multitenant with parameters of type ClusterModifierConstructorDescriptionRoundRobinSlotScheduler(TopologyDetails td, int slotsToUse, Cluster cluster) Create a new scheduler for a given topology.
- 
Uses of Cluster in org.apache.storm.scheduler.resourceMethods in org.apache.storm.scheduler.resource with parameters of type ClusterModifier and TypeMethodDescriptionRasNodes.getAllNodesFrom(Cluster cluster) voidUser.markTopoUnsuccess(TopologyDetails topo, Cluster cluster, String msg) voidResourceAwareScheduler.schedule(Topologies topologies, Cluster cluster) Constructors in org.apache.storm.scheduler.resource with parameters of type ClusterModifierConstructorDescriptionRasNode(String nodeId, SupervisorDetails sup, Cluster cluster, Map<String, WorkerSlot> workerIdToWorker, Map<String, Map<String, Collection<ExecutorDetails>>> assignmentMap) Create a new node.
- 
Uses of Cluster in org.apache.storm.scheduler.resource.strategies.schedulingFields in org.apache.storm.scheduler.resource.strategies.scheduling declared as ClusterMethods in org.apache.storm.scheduler.resource.strategies.scheduling with parameters of type ClusterModifier 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).
- 
Uses of Cluster in org.apache.storm.scheduler.resource.strategies.scheduling.sorterFields in org.apache.storm.scheduler.resource.strategies.scheduling.sorter declared as ClusterModifier and TypeFieldDescriptionprotected ClusterNodeSorter.clusterprotected ClusterNodeSorterHostProximity.clusterConstructors in org.apache.storm.scheduler.resource.strategies.scheduling.sorter with parameters of type ClusterModifierConstructorDescriptionExecSorterByConstraintSeverity(Cluster cluster, 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.