Modifier and Type | Method and Description |
---|---|
Assignment |
InMemoryAssignmentBackend.getAssignment(String stormId) |
Assignment |
ILocalAssignmentsBackend.getAssignment(String stormId)
Get assignment as
Assignment for a storm. |
Modifier and Type | Method and Description |
---|---|
Map<String,Assignment> |
InMemoryAssignmentBackend.assignmentsInfo() |
Map<String,Assignment> |
ILocalAssignmentsBackend.assignmentsInfo()
Get all the local assignments of local state.
|
Modifier and Type | Method and Description |
---|---|
void |
InMemoryAssignmentBackend.keepOrUpdateAssignment(String stormId,
Assignment assignment) |
void |
ILocalAssignmentsBackend.keepOrUpdateAssignment(String stormId,
Assignment assignment)
Keep a storm assignment to local state or update old assignment.
|
Modifier and Type | Method and Description |
---|---|
Assignment |
StormClusterStateImpl.assignmentInfo(String stormId,
Runnable callback) |
Assignment |
IStormClusterState.assignmentInfo(String stormId,
Runnable callback)
Get the assignment based on storm id from local backend.
|
Assignment |
StormClusterStateImpl.remoteAssignmentInfo(String stormId,
Runnable callback) |
Assignment |
IStormClusterState.remoteAssignmentInfo(String stormId,
Runnable callback)
Get the assignment based on storm id from remote state store, eg: ZK.
|
Modifier and Type | Method and Description |
---|---|
VersionedData<Assignment> |
StormClusterStateImpl.assignmentInfoWithVersion(String stormId,
Runnable callback) |
VersionedData<Assignment> |
IStormClusterState.assignmentInfoWithVersion(String stormId,
Runnable callback) |
Map<String,Assignment> |
StormClusterStateImpl.assignmentsInfo() |
Map<String,Assignment> |
IStormClusterState.assignmentsInfo()
Get all the topologies assignments mapping stormId -> Assignment from local backend.
|
Modifier and Type | Method and Description |
---|---|
void |
StormClusterStateImpl.setAssignment(String stormId,
Assignment info,
Map<String,Object> topoConf) |
void |
IStormClusterState.setAssignment(String stormId,
Assignment info,
Map<String,Object> topoConf) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
static List<String> |
Nimbus.topologiesOnSupervisor(Map<String,Assignment> assignments,
String supervisorId) |
Constructor and Description |
---|
TopologyResources(TopologyDetails td,
Assignment assignment) |
Modifier and Type | Method and Description |
---|---|
protected Map<String,Assignment> |
ReadClusterState.getAssignmentsSnapshot(IStormClusterState stormClusterState) |
Modifier and Type | Method and Description |
---|---|
protected Map<Integer,LocalAssignment> |
ReadClusterState.readMyExecutors(String topoId,
String assignmentId,
Assignment assignment) |
Modifier and Type | Method and Description |
---|---|
protected Map<Integer,LocalAssignment> |
ReadClusterState.readAssignments(Map<String,Assignment> assignmentsSnapshot) |
Modifier and Type | Method and Description |
---|---|
AtomicReference<Map<String,VersionedData<Assignment>>> |
WorkerState.getAssignmentVersions() |
Modifier and Type | Method and Description |
---|---|
void |
WorkerState.suicideIfLocalAssignmentsChanged(Assignment assignment) |
Modifier and Type | Method and Description |
---|---|
Assignment |
Assignment.deepCopy() |
Assignment |
Supervisor.getLocalAssignmentForStorm_result.get_success() |
Assignment |
Supervisor.Iface.getLocalAssignmentForStorm(String id)
Get local assignment for a storm
|
Assignment |
Supervisor.Client.getLocalAssignmentForStorm(String id) |
Assignment |
Supervisor.AsyncClient.getLocalAssignmentForStorm_call.getResult() |
Assignment |
Supervisor.Client.recv_getLocalAssignmentForStorm() |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
void |
Supervisor.AsyncIface.getLocalAssignmentForStorm(String id,
org.apache.storm.thrift.async.AsyncMethodCallback<Assignment> resultHandler) |
void |
Supervisor.AsyncClient.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) |
Constructor and Description |
---|
Assignment(Assignment other)
Performs a deep copy on other.
|
getLocalAssignmentForStorm_result(Assignment success,
NotAliveException e,
AuthorizationException aze) |
Constructor and 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) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.