| Package | Description | 
|---|---|
| org.apache.storm | |
| org.apache.storm.cluster | |
| org.apache.storm.daemon.nimbus | |
| org.apache.storm.daemon.supervisor | |
| org.apache.storm.daemon.ui | |
| org.apache.storm.generated | 
| Modifier and Type | Method and Description | 
|---|---|
List<ProfileRequest> | 
LocalCluster.getComponentPendingProfileActions(String id,
                                 String componentId,
                                 ProfileAction action)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
LocalCluster.setWorkerProfiler(String id,
                 ProfileRequest profileRequest)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<ProfileRequest> | 
StormClusterStateImpl.getTopologyProfileRequests(String stormId)  | 
List<ProfileRequest> | 
IStormClusterState.getTopologyProfileRequests(String stormId)  | 
List<ProfileRequest> | 
StormClusterStateImpl.getWorkerProfileRequests(String stormId,
                        NodeInfo nodeInfo)  | 
List<ProfileRequest> | 
IStormClusterState.getWorkerProfileRequests(String stormId,
                        NodeInfo nodeInfo)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
StormClusterStateImpl.deleteTopologyProfileRequests(String stormId,
                             ProfileRequest profileRequest)  | 
void | 
IStormClusterState.deleteTopologyProfileRequests(String stormId,
                             ProfileRequest profileRequest)  | 
void | 
StormClusterStateImpl.setWorkerProfileRequest(String stormId,
                       ProfileRequest profileRequest)  | 
void | 
IStormClusterState.setWorkerProfileRequest(String stormId,
                       ProfileRequest profileRequest)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<ProfileRequest> | 
Nimbus.getComponentPendingProfileActions(String id,
                                 String componentId,
                                 ProfileAction action)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Nimbus.setWorkerProfiler(String topoId,
                 ProfileRequest profileRequest)  | 
| Modifier and Type | Method and Description | 
|---|---|
protected Map<String,List<ProfileRequest>> | 
ReadClusterState.getProfileActions(IStormClusterState stormClusterState,
                 List<String> stormIds)  | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
BasicContainer.runProfiling(ProfileRequest request,
            boolean stop)  | 
boolean | 
LocalContainer.runProfiling(ProfileRequest request,
            boolean stop)  | 
abstract boolean | 
Container.runProfiling(ProfileRequest request,
            boolean stop)
Run a profiling request. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static Map<String,Object> | 
UIHelpers.getActiveAction(ProfileRequest profileRequest,
               Map config,
               String topologyId)
getActiveAction. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ProfileRequest | 
ProfileRequest.deepCopy()  | 
ProfileRequest | 
Nimbus.setWorkerProfiler_args.get_profileRequest()  | 
| Modifier and Type | Method and Description | 
|---|---|
Iterator<ProfileRequest> | 
Nimbus.getComponentPendingProfileActions_result.get_success_iterator()  | 
List<ProfileRequest> | 
Nimbus.getComponentPendingProfileActions_result.get_success()  | 
List<ProfileRequest> | 
Nimbus.Iface.getComponentPendingProfileActions(String id,
                                 String component_id,
                                 ProfileAction action)  | 
List<ProfileRequest> | 
Nimbus.Client.getComponentPendingProfileActions(String id,
                                 String component_id,
                                 ProfileAction action)  | 
List<ProfileRequest> | 
Nimbus.AsyncClient.getComponentPendingProfileActions_call.getResult()  | 
org.apache.storm.thrift.async.AsyncMethodCallback<List<ProfileRequest>> | 
Nimbus.AsyncProcessor.getComponentPendingProfileActions.getResultHandler(org.apache.storm.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer fb,
                int seqid)  | 
List<ProfileRequest> | 
Nimbus.Client.recv_getComponentPendingProfileActions()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Nimbus.getComponentPendingProfileActions_result.add_to_success(ProfileRequest elem)  | 
int | 
ProfileRequest.compareTo(ProfileRequest other)  | 
boolean | 
ProfileRequest.equals(ProfileRequest that)  | 
void | 
Nimbus.Client.send_setWorkerProfiler(String id,
                      ProfileRequest profileRequest)  | 
void | 
Nimbus.setWorkerProfiler_args.set_profileRequest(ProfileRequest profileRequest)  | 
void | 
Nimbus.Iface.setWorkerProfiler(String id,
                 ProfileRequest profileRequest)  | 
void | 
Nimbus.Client.setWorkerProfiler(String id,
                 ProfileRequest profileRequest)  | 
void | 
Nimbus.AsyncIface.setWorkerProfiler(String id,
                 ProfileRequest profileRequest,
                 org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)  | 
void | 
Nimbus.AsyncClient.setWorkerProfiler(String id,
                 ProfileRequest profileRequest,
                 org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Nimbus.AsyncIface.getComponentPendingProfileActions(String id,
                                 String component_id,
                                 ProfileAction action,
                                 org.apache.storm.thrift.async.AsyncMethodCallback<List<ProfileRequest>> resultHandler)  | 
void | 
Nimbus.AsyncClient.getComponentPendingProfileActions(String id,
                                 String component_id,
                                 ProfileAction action,
                                 org.apache.storm.thrift.async.AsyncMethodCallback<List<ProfileRequest>> resultHandler)  | 
void | 
Nimbus.getComponentPendingProfileActions_result.set_success(List<ProfileRequest> success)  | 
void | 
Nimbus.AsyncProcessor.getComponentPendingProfileActions.start(I iface,
     Nimbus.getComponentPendingProfileActions_args args,
     org.apache.storm.thrift.async.AsyncMethodCallback<List<ProfileRequest>> resultHandler)  | 
| Constructor and Description | 
|---|
ProfileRequest(ProfileRequest other)
Performs a deep copy on other. 
 | 
setWorkerProfiler_args(String id,
                      ProfileRequest profileRequest)  | 
setWorkerProfiler_call(String id,
                      ProfileRequest profileRequest,
                      org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler,
                      org.apache.storm.thrift.async.TAsyncClient client,
                      org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory,
                      org.apache.storm.thrift.transport.TNonblockingTransport transport)  | 
| Constructor and Description | 
|---|
getComponentPendingProfileActions_call(String id,
                                      String component_id,
                                      ProfileAction action,
                                      org.apache.storm.thrift.async.AsyncMethodCallback<List<ProfileRequest>> resultHandler,
                                      org.apache.storm.thrift.async.TAsyncClient client,
                                      org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory,
                                      org.apache.storm.thrift.transport.TNonblockingTransport transport)  | 
getComponentPendingProfileActions_result(List<ProfileRequest> success)  | 
Copyright © 2022 The Apache Software Foundation. All rights reserved.