Package org.apache.storm.daemon.nimbus
Class Nimbus
java.lang.Object
org.apache.storm.daemon.nimbus.Nimbus
- All Implemented Interfaces:
- DaemonCommon,- Shutdownable,- Nimbus.Iface
- 
Nested Class SummaryNested Classes
- 
Field SummaryFieldsModifier and TypeFieldDescriptionstatic final SimpleVersionstatic final Subjectstatic final List<org.apache.storm.shade.org.apache.zookeeper.data.ACL>
- 
Constructor SummaryConstructorsConstructorDescriptionNimbus(Map<String, Object> conf, INimbus inimbus, IStormClusterState stormClusterState, NimbusInfo hostPortInfo, BlobStore blobStore, TopoCache topoCache, ILeaderElector leaderElector, IGroupMappingServiceProvider groupMapper, StormMetricsRegistry metricsRegistry) Nimbus(Map<String, Object> conf, INimbus inimbus, IStormClusterState stormClusterState, NimbusInfo hostPortInfo, BlobStore blobStore, ILeaderElector leaderElector, IGroupMappingServiceProvider groupMapper, StormMetricsRegistry metricsRegistry) 
- 
Method SummaryModifier and TypeMethodDescriptionvoidvoidaddSupervisor(Supervisor supervisor) Used for local cluster.booleanawaitLeadership(long timeout, TimeUnit timeUnit) beginBlobDownload(String key) beginCreateBlob(String key, SettableBlobMeta meta) beginUpdateBlob(String key) voidcancelBlobUpload(String session) voidvoidcheckAuthorization(String topoName, Map<String, Object> topoConf, String operation, ReqContext context) static voidcleanInbox(String dirLoc, int seconds) Deletes jar files in dirLoc older than seconds.voidvoiddeactivate(String topoName) voidEnable/disable logging the tuples generated in topology via an internal EventLogger bolt.voiddeleteBlob(String key) voidCleanup topologies and Jars.downloadBlobChunk(String session) downloadChunk(String id) filterAuthorized(String operation, Collection<String> topoIds) voidfinishBlobUpload(String session) voidfinishFileUpload(String location) voidforceDeleteTopoDistDir(String topoId) getBlobMeta(String key) intgetBlobReplication(String key) getComponentPageInfo(String topoId, String componentId, String window, boolean includeSys) getComponentPendingProfileActions(String id, String componentId, ProfileAction action) getLogConfig(String topoId) static List<org.apache.storm.shade.org.apache.zookeeper.data.ACL>getNimbusAcls(Map<String, Object> conf) getOwnerResourceSummaries(String owner) getSupervisorAssignments(String nodeId) Get assigned assignments for a specific supervisorgetSupervisorPageInfo(String superId, String host, boolean includeSys) 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 topoId, GetInfoOptions options) getTopologyPageInfo(String topoId, String window, boolean includeSys) Returns the user specified topology as submitted originally.static intgetVersionForKey(String key, NimbusInfo nimbusInfo, org.apache.storm.shade.org.apache.curator.framework.CuratorFramework zkClient) booleanisRemoteBlobExists(String blobKey) Decide if the blob is removed from cluster.booleanisTopologyNameAllowed(String name) booleanvoidkillTopology(String name) voidkillTopologyWithOpts(String topoName, KillOptions options) static Nimbusvoidstatic voidvoidprocessWorkerMetrics(WorkerMetrics metrics) voidrebalance(String topoName, RebalanceOptions options) voidrmDependencyJarsInTopology(String topoId) voidrmTopologyKeys(String topoId) voidSend supervisor local worker heartbeat when a supervisor is unreachablevoidSend supervisor worker heartbeats for a specific supervisorvoidsetAuthorizationHandler(IAuthorizer authorizationHandler) voidsetBlobMeta(String key, SettableBlobMeta meta) voidsetLogConfig(String topoId, LogConfig config) static voidsetUpAckerExecutorConfigs(String topoName, Map<String, Object> totalConfToSave, Map<String, Object> totalConf, int estimatedNumWorker) voidsetWorkerProfiler(String topoId, ProfileRequest profileRequest) voidshutdown()voidsubmitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) voidsubmitTopologyWithOpts(String topoName, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) topoIdsToClean(IStormClusterState state, BlobStore store, Map<String, Object> conf) topologiesOnSupervisor(Map<String, Assignment> assignments, String supervisorId) intupdateBlobReplication(String key, int replication) voiduploadBlobChunk(String session, ByteBuffer chunk) voiduploadChunk(String location, ByteBuffer chunk) voiduploadNewCredentials(String topoName, Credentials credentials) 
- 
Field Details- 
ZK_ACLS
- 
MIN_VERSION_SUPPORT_RPC_HEARTBEAT
- 
NIMBUS_SUBJECT
 
- 
- 
Constructor Details- 
Nimbuspublic Nimbus(Map<String, Object> conf, INimbus inimbus, StormMetricsRegistry metricsRegistry) throws Exception- Throws:
- Exception
 
- 
Nimbuspublic Nimbus(Map<String, Object> conf, INimbus inimbus, IStormClusterState stormClusterState, NimbusInfo hostPortInfo, BlobStore blobStore, ILeaderElector leaderElector, IGroupMappingServiceProvider groupMapper, StormMetricsRegistry metricsRegistry) throws Exception- Throws:
- Exception
 
- 
Nimbuspublic Nimbus(Map<String, Object> conf, INimbus inimbus, IStormClusterState stormClusterState, NimbusInfo hostPortInfo, BlobStore blobStore, TopoCache topoCache, ILeaderElector leaderElector, IGroupMappingServiceProvider groupMapper, StormMetricsRegistry metricsRegistry) throws Exception- Throws:
- Exception
 
 
- 
- 
Method Details- 
getNimbusAcls
- 
getVersionForKeypublic static int getVersionForKey(String key, NimbusInfo nimbusInfo, org.apache.storm.shade.org.apache.curator.framework.CuratorFramework zkClient) throws KeyNotFoundException - Throws:
- KeyNotFoundException
 
- 
topoIdsToClean
- 
cleanInboxDeletes jar files in dirLoc older than seconds.- Parameters:
- dirLoc- the location to look in for file
- seconds- how old is too old and should be deleted
 
- 
topologiesOnSupervisor
- 
launchServer- Throws:
- Exception
 
- 
launch- Throws:
- Exception
 
- 
main- Throws:
- Exception
 
- 
setAuthorizationHandler
- 
getHeartbeatsCache
- 
getIdToExecutors
- 
addSupervisorUsed for local cluster.- Parameters:
- supervisor-- Supervisor
 
- 
checkAuthorizationpublic void checkAuthorization(String topoName, Map<String, Object> topoConf, String operation) throws AuthorizationException- Throws:
- AuthorizationException
 
- 
checkAuthorizationpublic void checkAuthorization(String topoName, Map<String, Object> topoConf, String operation, ReqContext context) throws AuthorizationException- Throws:
- AuthorizationException
 
- 
filterAuthorizedpublic Set<String> filterAuthorized(String operation, Collection<String> topoIds) throws NotAliveException, AuthorizationException, IOException 
- 
rmDependencyJarsInTopology
- 
rmTopologyKeys
- 
forceDeleteTopoDistDir- Throws:
- IOException
 
- 
doCleanuppublic void doCleanup()Cleanup topologies and Jars.
- 
awaitLeadership- Throws:
- InterruptedException
 
- 
submitTopologypublic void submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) throws AlreadyAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- submitTopologyin interface- Nimbus.Iface
- Throws:
- AlreadyAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
submitTopologyWithOptspublic void submitTopologyWithOpts(String topoName, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) throws AlreadyAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- submitTopologyWithOptsin interface- Nimbus.Iface
- Throws:
- AlreadyAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
setUpAckerExecutorConfigs
- 
killTopologypublic void killTopology(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- killTopologyin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
killTopologyWithOptspublic void killTopologyWithOpts(String topoName, KillOptions options) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- killTopologyWithOptsin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
activatepublic void activate(String topoName) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- activatein interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
deactivatepublic void deactivate(String topoName) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- deactivatein interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
rebalancepublic void rebalance(String topoName, RebalanceOptions options) throws NotAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- rebalancein interface- Nimbus.Iface
- Throws:
- NotAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
setLogConfig- Specified by:
- setLogConfigin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getLogConfig- Specified by:
- getLogConfigin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
debugpublic void debug(String topoName, String componentId, boolean enable, double samplingPercentage) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceEnable/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.- Specified by:
- debugin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
setWorkerProfilerpublic void setWorkerProfiler(String topoId, ProfileRequest profileRequest) throws org.apache.storm.thrift.TException - Specified by:
- setWorkerProfilerin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getComponentPendingProfileActionspublic List<ProfileRequest> getComponentPendingProfileActions(String id, String componentId, ProfileAction action) throws org.apache.storm.thrift.TException - Specified by:
- getComponentPendingProfileActionsin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
uploadNewCredentialspublic void uploadNewCredentials(String topoName, Credentials credentials) throws NotAliveException, InvalidTopologyException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- uploadNewCredentialsin interface- Nimbus.Iface
- Throws:
- NotAliveException
- InvalidTopologyException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
beginCreateBlobpublic String beginCreateBlob(String key, SettableBlobMeta meta) throws AuthorizationException, KeyAlreadyExistsException, org.apache.storm.thrift.TException - Specified by:
- beginCreateBlobin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyAlreadyExistsException
- org.apache.storm.thrift.TException
 
- 
beginUpdateBlobpublic String beginUpdateBlob(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Specified by:
- beginUpdateBlobin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
uploadBlobChunkpublic void uploadBlobChunk(String session, ByteBuffer chunk) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- uploadBlobChunkin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
finishBlobUploadpublic void finishBlobUpload(String session) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- finishBlobUploadin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
cancelBlobUploadpublic void cancelBlobUpload(String session) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- cancelBlobUploadin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getBlobMetapublic ReadableBlobMeta getBlobMeta(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Specified by:
- getBlobMetain interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
setBlobMetapublic void setBlobMeta(String key, SettableBlobMeta meta) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Specified by:
- setBlobMetain interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
beginBlobDownloadpublic BeginDownloadResult beginBlobDownload(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Specified by:
- beginBlobDownloadin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
downloadBlobChunkpublic ByteBuffer downloadBlobChunk(String session) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- downloadBlobChunkin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
deleteBlobpublic void deleteBlob(String key) throws AuthorizationException, KeyNotFoundException, IllegalStateException, org.apache.storm.thrift.TException - Specified by:
- deleteBlobin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- IllegalStateException
- org.apache.storm.thrift.TException
 
- 
listBlobs- Specified by:
- listBlobsin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getBlobReplicationpublic int getBlobReplication(String key) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Specified by:
- getBlobReplicationin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
updateBlobReplicationpublic int updateBlobReplication(String key, int replication) throws AuthorizationException, KeyNotFoundException, org.apache.storm.thrift.TException - Specified by:
- updateBlobReplicationin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- org.apache.storm.thrift.TException
 
- 
createStateInZookeeper- Specified by:
- createStateInZookeeperin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
beginFileUpload- Specified by:
- beginFileUploadin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
uploadChunkpublic void uploadChunk(String location, ByteBuffer chunk) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- uploadChunkin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
finishFileUploadpublic void finishFileUpload(String location) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- finishFileUploadin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
downloadChunkpublic ByteBuffer downloadChunk(String id) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- downloadChunkin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getNimbusConf- Specified by:
- getNimbusConfin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfopublic TopologyInfo getTopologyInfo(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologyInfoin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoByName- Specified by:
- getTopologyInfoByNamein interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoByNameWithOptspublic TopologyInfo getTopologyInfoByNameWithOpts(String name, GetInfoOptions options) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologyInfoByNameWithOptsin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoWithOptspublic TopologyInfo getTopologyInfoWithOpts(String topoId, GetInfoOptions options) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologyInfoWithOptsin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyPageInfopublic TopologyPageInfo getTopologyPageInfo(String topoId, String window, boolean includeSys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologyPageInfoin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getSupervisorPageInfopublic SupervisorPageInfo getSupervisorPageInfo(String superId, String host, boolean includeSys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getSupervisorPageInfoin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getComponentPageInfopublic ComponentPageInfo getComponentPageInfo(String topoId, String componentId, String window, boolean includeSys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getComponentPageInfoin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyConfpublic String getTopologyConf(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologyConfin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologypublic StormTopology getTopology(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceReturns the compiled topology that contains ackers and metrics consumsers. CompareNimbus.Iface.getUserTopology(String id).- Specified by:
- getTopologyin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getUserTopologypublic StormTopology getUserTopology(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceReturns the user specified topology as submitted originally. CompareNimbus.Iface.getTopology(String id).- Specified by:
- getUserTopologyin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologyHistorypublic TopologyHistoryInfo getTopologyHistory(String user) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologyHistoryin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getClusterInfopublic ClusterSummary getClusterInfo() throws AuthorizationException, org.apache.storm.thrift.TException- Specified by:
- getClusterInfoin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologySummariespublic List<TopologySummary> getTopologySummaries() throws AuthorizationException, org.apache.storm.thrift.TException- Specified by:
- getTopologySummariesin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologySummaryByNamepublic TopologySummary getTopologySummaryByName(String name) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologySummaryByNamein interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getTopologySummarypublic TopologySummary getTopologySummary(String id) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getTopologySummaryin interface- Nimbus.Iface
- Throws:
- NotAliveException
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getLeader- Specified by:
- getLeaderin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
isTopologyNameAllowedpublic boolean isTopologyNameAllowed(String name) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- isTopologyNameAllowedin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getOwnerResourceSummariespublic List<OwnerResourceSummary> getOwnerResourceSummaries(String owner) throws AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getOwnerResourceSummariesin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
getSupervisorAssignmentspublic SupervisorAssignments getSupervisorAssignments(String nodeId) throws AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceGet assigned assignments for a specific supervisor- Specified by:
- getSupervisorAssignmentsin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
sendSupervisorWorkerHeartbeatspublic void sendSupervisorWorkerHeartbeats(SupervisorWorkerHeartbeats heartbeats) throws AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceSend supervisor worker heartbeats for a specific supervisor- Specified by:
- sendSupervisorWorkerHeartbeatsin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
sendSupervisorWorkerHeartbeatpublic void sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat hb) throws AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceSend supervisor local worker heartbeat when a supervisor is unreachable- Specified by:
- sendSupervisorWorkerHeartbeatin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
- 
shutdownpublic void shutdown()- Specified by:
- shutdownin interface- Shutdownable
 
- 
isWaitingpublic boolean isWaiting()- Specified by:
- isWaitingin interface- DaemonCommon
 
- 
processWorkerMetrics- Specified by:
- processWorkerMetricsin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
isRemoteBlobExistspublic boolean isRemoteBlobExists(String blobKey) throws AuthorizationException, org.apache.storm.thrift.TException Description copied from interface:Nimbus.IfaceDecide if the blob is removed from cluster.- Specified by:
- isRemoteBlobExistsin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- org.apache.storm.thrift.TException
 
 
-