Package org.apache.storm.generated
Interface Nimbus.Iface
- All Known Implementing Classes:
- LocalCluster,- Nimbus,- Nimbus.Client
- Enclosing class:
- Nimbus
public static interface Nimbus.Iface
- 
Method SummaryModifier and TypeMethodDescriptionvoidbeginBlobDownload(String key) beginCreateBlob(String key, SettableBlobMeta meta) beginUpdateBlob(String key) voidcancelBlobUpload(String session) voidvoiddeactivate(String name) voidEnable/disable logging the tuples generated in topology via an internal EventLogger bolt.voiddeleteBlob(String key) downloadBlobChunk(String session) downloadChunk(String id) voidfinishBlobUpload(String session) voidfinishFileUpload(String location) getBlobMeta(String key) intgetBlobReplication(String key) getComponentPageInfo(String topology_id, String component_id, String window, boolean is_include_sys) getComponentPendingProfileActions(String id, String component_id, ProfileAction action) getLogConfig(String name) getOwnerResourceSummaries(String owner) Get assigned assignments for a specific supervisorgetSupervisorPageInfo(String id, String host, boolean is_include_sys) getTopology(String id) Returns the compiled topology that contains ackers and metrics consumsers.getTopologyHistory(String user) getTopologyInfoByName(String name) getTopologyInfoByNameWithOpts(String name, GetInfoOptions options) getTopologyInfoWithOpts(String id, GetInfoOptions options) getTopologyPageInfo(String id, String window, boolean is_include_sys) Returns the user specified topology as submitted originally.booleanisRemoteBlobExists(String blobKey) Decide if the blob is removed from cluster.booleanisTopologyNameAllowed(String name) voidkillTopology(String name) voidkillTopologyWithOpts(String name, KillOptions options) voidprocessWorkerMetrics(WorkerMetrics metrics) voidrebalance(String name, RebalanceOptions options) voidSend supervisor local worker heartbeat when a supervisor is unreachablevoidSend supervisor worker heartbeats for a specific supervisorvoidsetBlobMeta(String key, SettableBlobMeta meta) voidsetLogConfig(String name, LogConfig config) voidsetWorkerProfiler(String id, ProfileRequest profileRequest) voidsubmitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) voidsubmitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) intupdateBlobReplication(String key, int replication) voiduploadBlobChunk(String session, ByteBuffer chunk) voiduploadChunk(String location, ByteBuffer chunk) voiduploadNewCredentials(String name, Credentials creds) 
- 
Method Details- 
submitTopologyvoid submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) throws AlreadyAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AlreadyAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
submitTopologyWithOptsvoid submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) throws AlreadyAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AlreadyAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
killTopologyvoid killTopology(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
killTopologyWithOptsvoid killTopologyWithOpts(String name, KillOptions options) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
activatevoid activate(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
deactivatevoid deactivate(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
rebalancevoid rebalance(String name, RebalanceOptions options) throws NotAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
setLogConfig- Throws:
- org.apache.storm.thrift.TException
 
- 
getLogConfig- Throws:
- org.apache.storm.thrift.TException
 
- 
debugvoid debug(String name, String component, boolean enable, double samplingPercentage) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException Enable/disable logging the tuples generated in topology via an internal EventLogger bolt. The component name is optional and if null or empty, the debug flag will apply to the entire topology. The 'samplingPercentage' will limit loggging to a percentage of generated tuples.- Parameters:
- name-
- component-
- enable-
- samplingPercentage-
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
setWorkerProfilervoid setWorkerProfiler(String id, ProfileRequest profileRequest) throws org.apache.storm.thrift.TException - Throws:
- org.apache.storm.thrift.TException
 
- 
getComponentPendingProfileActionsList<ProfileRequest> getComponentPendingProfileActions(String id, String component_id, ProfileAction action) throws org.apache.storm.thrift.TException - Throws:
- org.apache.storm.thrift.TException
 
- 
uploadNewCredentialsvoid uploadNewCredentials(String name, Credentials creds) throws NotAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
beginCreateBlobString beginCreateBlob(String key, SettableBlobMeta meta) throws AuthorizationException, KeyAlreadyExistsException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyAlreadyExistsException
- org.apache.storm.thrift.TException
 
- 
beginUpdateBlobString beginUpdateBlob(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
uploadBlobChunkvoid uploadBlobChunk(String session, ByteBuffer chunk) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
finishBlobUploadvoid finishBlobUpload(String session) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
cancelBlobUploadvoid cancelBlobUpload(String session) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getBlobMetaReadableBlobMeta getBlobMeta(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
setBlobMetavoid setBlobMeta(String key, SettableBlobMeta meta) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
beginBlobDownloadBeginDownloadResult beginBlobDownload(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
downloadBlobChunkByteBuffer downloadBlobChunk(String session) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
deleteBlobvoid deleteBlob(String key) throws AuthorizationException, KeyNotFoundException, IllegalStateException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- IllegalStateException
- org.apache.storm.thrift.TException
 
- 
listBlobs- Throws:
- org.apache.storm.thrift.TException
 
- 
getBlobReplicationint getBlobReplication(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
updateBlobReplicationint updateBlobReplication(String key, int replication) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
createStateInZookeeper- Throws:
- org.apache.storm.thrift.TException
 
- 
beginFileUpload- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
uploadChunkvoid uploadChunk(String location, ByteBuffer chunk) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
finishFileUploadvoid finishFileUpload(String location) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
downloadChunkByteBuffer downloadChunk(String id) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getNimbusConf- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getClusterInfo- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologySummariesList<TopologySummary> getTopologySummaries() throws AuthorizationException, org.apache.storm.thrift.TException- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologySummaryByNameTopologySummary getTopologySummaryByName(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologySummaryTopologySummary getTopologySummary(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getLeader- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
isTopologyNameAllowedboolean isTopologyNameAllowed(String name) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoByNameTopologyInfo getTopologyInfoByName(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoTopologyInfo getTopologyInfo(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoByNameWithOptsTopologyInfo getTopologyInfoByNameWithOpts(String name, GetInfoOptions options) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoWithOptsTopologyInfo getTopologyInfoWithOpts(String id, GetInfoOptions options) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyPageInfoTopologyPageInfo getTopologyPageInfo(String id, String window, boolean is_include_sys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getSupervisorPageInfoSupervisorPageInfo getSupervisorPageInfo(String id, String host, boolean is_include_sys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getComponentPageInfoComponentPageInfo getComponentPageInfo(String topology_id, String component_id, String window, boolean is_include_sys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyConfString getTopologyConf(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyStormTopology getTopology(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException Returns the compiled topology that contains ackers and metrics consumsers. ComparegetUserTopology(String id).- Parameters:
- id-
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getUserTopologyStormTopology getUserTopology(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException Returns the user specified topology as submitted originally. ComparegetTopology(String id).- Parameters:
- id-
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyHistoryTopologyHistoryInfo getTopologyHistory(String user) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getOwnerResourceSummariesList<OwnerResourceSummary> getOwnerResourceSummaries(String owner) throws AuthorizationException, org.apache.storm.thrift.TException - Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getSupervisorAssignmentsSupervisorAssignments getSupervisorAssignments(String node) throws AuthorizationException, org.apache.storm.thrift.TException Get assigned assignments for a specific supervisor- Parameters:
- node-
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
sendSupervisorWorkerHeartbeatsvoid sendSupervisorWorkerHeartbeats(SupervisorWorkerHeartbeats heartbeats) throws AuthorizationException, org.apache.storm.thrift.TException Send supervisor worker heartbeats for a specific supervisor- Parameters:
- heartbeats-
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
sendSupervisorWorkerHeartbeatvoid sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat heatbeat) throws AuthorizationException, NotAliveException, org.apache.storm.thrift.TException Send supervisor local worker heartbeat when a supervisor is unreachable- Parameters:
- heatbeat-
- Throws:
- AuthorizationException
- NotAliveException
- org.apache.storm.thrift.TException
 
- 
processWorkerMetrics- Throws:
- org.apache.storm.thrift.TException
 
- 
isRemoteBlobExistsboolean isRemoteBlobExists(String blobKey) throws AuthorizationException, org.apache.storm.thrift.TException Decide if the blob is removed from cluster.- Parameters:
- blobKey-
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
 
-