Uses of Class
org.apache.storm.generated.Assignment
-
-
Uses of Assignment in org.apache.storm.assignments
Methods in org.apache.storm.assignments that return Assignment Modifier and Type Method Description Assignment
ILocalAssignmentsBackend. getAssignment(String stormId)
Get assignment asAssignment
for a storm.Assignment
InMemoryAssignmentBackend. getAssignment(String stormId)
Methods in org.apache.storm.assignments that return types with arguments of type Assignment Modifier and Type Method Description Map<String,Assignment>
ILocalAssignmentsBackend. assignmentsInfo()
Get all the local assignments of local state.Map<String,Assignment>
InMemoryAssignmentBackend. assignmentsInfo()
Methods in org.apache.storm.assignments with parameters of type Assignment Modifier and Type Method Description void
ILocalAssignmentsBackend. keepOrUpdateAssignment(String stormId, Assignment assignment)
Keep a storm assignment to local state or update old assignment.void
InMemoryAssignmentBackend. keepOrUpdateAssignment(String stormId, Assignment assignment)
-
Uses of Assignment in org.apache.storm.cluster
Methods in org.apache.storm.cluster that return Assignment Modifier and Type Method Description Assignment
IStormClusterState. assignmentInfo(String stormId, Runnable callback)
Get the assignment based on storm id from local backend.Assignment
StormClusterStateImpl. assignmentInfo(String stormId, Runnable callback)
Assignment
IStormClusterState. remoteAssignmentInfo(String stormId, Runnable callback)
Get the assignment based on storm id from remote state store, eg: ZK.Assignment
StormClusterStateImpl. remoteAssignmentInfo(String stormId, Runnable callback)
Methods in org.apache.storm.cluster that return types with arguments of type Assignment Modifier and Type Method Description VersionedData<Assignment>
IStormClusterState. assignmentInfoWithVersion(String stormId, Runnable callback)
VersionedData<Assignment>
StormClusterStateImpl. assignmentInfoWithVersion(String stormId, Runnable callback)
Map<String,Assignment>
IStormClusterState. assignmentsInfo()
Get all the topologies assignments mapping stormId -> Assignment from local backend.Map<String,Assignment>
StormClusterStateImpl. assignmentsInfo()
Methods in org.apache.storm.cluster with parameters of type Assignment Modifier and Type Method Description void
IStormClusterState. setAssignment(String stormId, Assignment info, Map<String,Object> topoConf)
void
StormClusterStateImpl. setAssignment(String stormId, Assignment info, Map<String,Object> topoConf)
-
Uses of Assignment in org.apache.storm.daemon.nimbus
Methods in org.apache.storm.daemon.nimbus with parameters of type Assignment Modifier and Type Method Description Set<List<Integer>>
HeartbeatCache. getAliveExecutors(String topoId, Set<List<Integer>> allExecutors, Assignment assignment, int taskLaunchSecs)
Get all of the alive executors for a given topology.Method parameters in org.apache.storm.daemon.nimbus with type arguments of type Assignment Modifier and Type Method Description static List<String>
Nimbus. topologiesOnSupervisor(Map<String,Assignment> assignments, String supervisorId)
Constructors in org.apache.storm.daemon.nimbus with parameters of type Assignment Constructor Description TopologyResources(TopologyDetails td, Assignment assignment)
-
Uses of Assignment in org.apache.storm.daemon.supervisor
Methods in org.apache.storm.daemon.supervisor that return types with arguments of type Assignment Modifier and Type Method Description protected Map<String,Assignment>
ReadClusterState. getAssignmentsSnapshot(IStormClusterState stormClusterState)
Methods in org.apache.storm.daemon.supervisor with parameters of type Assignment Modifier and Type Method Description protected Map<Integer,LocalAssignment>
ReadClusterState. readMyExecutors(String topoId, String assignmentId, Assignment assignment)
Method parameters in org.apache.storm.daemon.supervisor with type arguments of type Assignment Modifier and Type Method Description protected Map<Integer,LocalAssignment>
ReadClusterState. readAssignments(Map<String,Assignment> assignmentsSnapshot)
-
Uses of Assignment in org.apache.storm.daemon.worker
Methods in org.apache.storm.daemon.worker that return types with arguments of type Assignment Modifier and Type Method Description AtomicReference<Map<String,VersionedData<Assignment>>>
WorkerState. getAssignmentVersions()
Methods in org.apache.storm.daemon.worker with parameters of type Assignment Modifier and Type Method Description void
WorkerState. suicideIfLocalAssignmentsChanged(Assignment assignment)
-
Uses of Assignment in org.apache.storm.generated
Methods in org.apache.storm.generated that return Assignment Modifier and Type Method Description Assignment
Assignment. deepCopy()
Assignment
Supervisor.getLocalAssignmentForStorm_result. get_success()
Assignment
Supervisor.Client. getLocalAssignmentForStorm(String id)
Assignment
Supervisor.Iface. getLocalAssignmentForStorm(String id)
Get local assignment for a stormAssignment
Supervisor.AsyncClient.getLocalAssignmentForStorm_call. getResult()
Assignment
Supervisor.Client. recv_getLocalAssignmentForStorm()
Methods in org.apache.storm.generated that return types with arguments of type Assignment Modifier and Type Method Description Map<String,Assignment>
SupervisorAssignments. get_storm_assignment()
org.apache.storm.thrift.async.AsyncMethodCallback<Assignment>
Supervisor.AsyncProcessor.getLocalAssignmentForStorm. getResultHandler(org.apache.storm.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer fb, int seqid)
Methods in org.apache.storm.generated with parameters of type Assignment Modifier and Type Method Description int
Assignment. compareTo(Assignment other)
boolean
Assignment. equals(Assignment that)
void
SupervisorAssignments. put_to_storm_assignment(String key, Assignment val)
void
Supervisor.getLocalAssignmentForStorm_result. set_success(Assignment success)
Method parameters in org.apache.storm.generated with type arguments of type Assignment Modifier and Type Method Description void
Supervisor.AsyncClient. getLocalAssignmentForStorm(String id, org.apache.storm.thrift.async.AsyncMethodCallback<Assignment> resultHandler)
void
Supervisor.AsyncIface. getLocalAssignmentForStorm(String id, org.apache.storm.thrift.async.AsyncMethodCallback<Assignment> resultHandler)
void
SupervisorAssignments. set_storm_assignment(Map<String,Assignment> storm_assignment)
void
Supervisor.AsyncProcessor.getLocalAssignmentForStorm. start(I iface, Supervisor.getLocalAssignmentForStorm_args args, org.apache.storm.thrift.async.AsyncMethodCallback<Assignment> resultHandler)
Constructors in org.apache.storm.generated with parameters of type Assignment Constructor Description Assignment(Assignment other)
Performs a deep copy on other.getLocalAssignmentForStorm_result(Assignment success, NotAliveException e, AuthorizationException aze)
Constructor parameters in org.apache.storm.generated with type arguments of type Assignment Constructor Description getLocalAssignmentForStorm_call(String id, org.apache.storm.thrift.async.AsyncMethodCallback<Assignment> resultHandler, org.apache.storm.thrift.async.TAsyncClient client, org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory, org.apache.storm.thrift.transport.TNonblockingTransport transport)
-