Package org.apache.storm
Class LocalCluster
java.lang.Object
org.apache.storm.LocalCluster
- All Implemented Interfaces:
- AutoCloseable,- Nimbus.Iface,- ILocalCluster,- ILocalClusterTrackedTopologyAware
A stand alone storm cluster that runs inside a single process. It is intended to be used for testing.  Both internal testing for Apache
 Storm itself and for people building storm topologies.
 
LocalCluster is an AutoCloseable so if you are using it in tests you can use a try block to be sure it is shut down.
try (LocalCluster cluster = new LocalCluster()) { // Do some tests } // The cluster has been shut down.- 
Nested Class SummaryNested ClassesModifier and TypeClassDescriptionstatic classSimple way to configure a LocalCluster to meet your needs.classWhen running a topology locally, for tests etc.Nested classes/interfaces inherited from interface org.apache.storm.ILocalClusterILocalCluster.ILocalTopology
- 
Field SummaryFields
- 
Constructor SummaryConstructorsConstructorDescriptionCreate a default LocalCluster.LocalCluster(String zkHost, Long zkPort) Create a LocalCluster that connects to an existing Zookeeper instance.
- 
Method SummaryModifier and TypeMethodDescriptionvoidActivate a topology.Add another supervisor to the topology.addSupervisor(Number ports) Add another supervisor to the topology.addSupervisor(Number ports, String id) Add another supervisor to the topology.Add another supervisor to the topology.voidadvanceClusterTime(int secs) Advance the cluster time when the cluster is using SimulatedTime.voidadvanceClusterTime(int secs, int incSecs) Advance the cluster time when the cluster is using SimulatedTime.beginBlobDownload(String key) beginCreateBlob(String key, SettableBlobMeta meta) beginUpdateBlob(String key) voidcancelBlobUpload(String session) voidclose()voidvoiddeactivate(String topologyName) Deactivate a topology.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) Get cluster information.This is intended for internal testing only.getComponentPageInfo(String topologyId, String componentId, String window, boolean isIncludeSys) getComponentPendingProfileActions(String id, String componentId, ProfileAction action) Get daemon configuration.getLogConfig(String name) Reference to metrics registry.Reference to nimbus.getOwnerResourceSummaries(String owner) getSupervisor(String id) Get a specific Supervisor.Get assigned assignments for a specific supervisorgetSupervisorPageInfo(String id, String host, boolean isIncludeSys) intgetTopology(String id) Get the compiled storm topology.The config of a topology as a JSON string.getTopologyHistory(String user) Get the state of a topology.getTopologyInfoByName(String name) Get the state of a topology.getTopologyInfoByNameWithOpts(String name, GetInfoOptions options) Get the state of a topology.getTopologyInfoWithOpts(String id, GetInfoOptions options) Get the state of a topology.getTopologyPageInfo(String id, String window, boolean isIncludeSys) If the cluster is tracked get the id for the tracked cluster.Returns the user specified topology as submitted originally.booleanisRemoteBlobExists(String blobKey) Decide if the blob is removed from cluster.booleanisTopologyNameAllowed(String name) voidkillSupervisor(String id) Kill a specific supervisor.voidkillTopology(String topologyName) Kill a topology (if you are not using ILocalTopology).voidkillTopologyWithOpts(String name, KillOptions options) Kill a topology (if you are not using ILocalTopology).static voidMain entry point to running in local mode.voidprocessWorkerMetrics(WorkerMetrics metrics) voidrebalance(String name, RebalanceOptions options) Rebalance a topology.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) voidshutdown()Shut down the cluster.voidsubmitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) submitTopology(String topologyName, Map<String, Object> conf, StormTopology topology) Submit a topology to be run in local mode.submitTopology(String topologyName, Map<String, Object> conf, TrackedTopology topology) Submit a tracked topology to be run in local mode.voidsubmitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) submitTopologyWithOpts(String topologyName, Map<String, Object> conf, StormTopology topology, SubmitOptions submitOpts) Submit a topology to be run in local mode.submitTopologyWithOpts(String topologyName, Map<String, Object> conf, TrackedTopology topology, SubmitOptions submitOpts) Submit a tracked topology to be run in local mode.intupdateBlobReplication(String key, int replication) voiduploadBlobChunk(String session, ByteBuffer chunk) voiduploadChunk(String location, ByteBuffer chunk) voiduploadNewCredentials(String topologyName, Credentials creds) Upload new credentials to a topology.voidWait for the cluster to be idle.voidwaitForIdle(long timeoutMs) Wait for the cluster to be idle.static <T> TwithLocalModeOverride(Callable<T> c, long ttlSec) Run c with a local mode cluster overriding the NimbusClient and DRPCClient calls.static <T> TwithLocalModeOverride(Callable<T> c, long ttlSec, Map<String, Object> daemonConf) Run c with a local mode cluster overriding the NimbusClient and DRPCClient calls.
- 
Field Details- 
KILL_NOW
 
- 
- 
Constructor Details
- 
Method Details- 
withLocalModeOverrideRun c with a local mode cluster overriding the NimbusClient and DRPCClient calls. NOTE local mode override happens by default now unless netty is turned on for the local cluster.- Parameters:
- c- the callable to run in this mode
- ttlSec- the number of seconds to let the cluster run after c has completed
- Returns:
- the result of calling C
- Throws:
- Exception- on any Exception.
 
- 
withLocalModeOverridepublic static <T> T withLocalModeOverride(Callable<T> c, long ttlSec, Map<String, Object> daemonConf) throws ExceptionRun c with a local mode cluster overriding the NimbusClient and DRPCClient calls. NOTE local mode override happens by default now unless netty is turned on for the local cluster.- Parameters:
- c- the callable to run in this mode
- ttlSec- the number of seconds to let the cluster run after c has completed
- daemonConf- configs to set for the daemon processes.
- Returns:
- the result of calling C
- Throws:
- Exception- on any Exception.
 
- 
mainMain entry point to running in local mode.- Parameters:
- args- arguments to be run in local mode
- Throws:
- Exception- on any error when running.
 
- 
getNimbusReference to nimbus.- Returns:
- Nimbus itself so you can interact with it directly, if needed.
 
- 
getMetricRegistryReference to metrics registry.- Returns:
- The metrics registry for the local cluster.
 
- 
getDaemonConfGet daemon configuration.- Returns:
- the base config for the daemons
 
- 
submitTopologypublic LocalCluster.LocalTopology submitTopology(String topologyName, Map<String, Object> conf, StormTopology topology) throws org.apache.storm.thrift.TExceptionDescription copied from interface:ILocalClusterSubmit a topology to be run in local mode.- Specified by:
- submitTopologyin interface- ILocalCluster
- Parameters:
- topologyName- the name of the topology to use
- conf- the config for the topology
- topology- the topology itself.
- Returns:
- an AutoCloseable that will kill the topology.
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
submitTopologypublic LocalCluster.LocalTopology submitTopology(String topologyName, Map<String, Object> conf, TrackedTopology topology) throws org.apache.storm.thrift.TExceptionDescription copied from interface:ILocalClusterTrackedTopologyAwareSubmit a tracked topology to be run in local mode.- Specified by:
- submitTopologyin interface- ILocalClusterTrackedTopologyAware
- Parameters:
- topologyName- the name of the topology to use
- conf- the config for the topology
- topology- the topology itself.
- Returns:
- an AutoCloseable that will kill the topology.
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
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 LocalCluster.LocalTopology submitTopologyWithOpts(String topologyName, Map<String, Object> conf, StormTopology topology, SubmitOptions submitOpts) throws org.apache.storm.thrift.TExceptionDescription copied from interface:ILocalClusterSubmit a topology to be run in local mode.- Specified by:
- submitTopologyWithOptsin interface- ILocalCluster
- Parameters:
- topologyName- the name of the topology to use
- conf- the config for the topology
- topology- the topology itself.
- submitOpts- options for topology
- Returns:
- an AutoCloseable that will kill the topology.
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
submitTopologyWithOptspublic LocalCluster.LocalTopology submitTopologyWithOpts(String topologyName, Map<String, Object> conf, TrackedTopology topology, SubmitOptions submitOpts) throws org.apache.storm.thrift.TExceptionDescription copied from interface:ILocalClusterTrackedTopologyAwareSubmit a tracked topology to be run in local mode.- Specified by:
- submitTopologyWithOptsin interface- ILocalClusterTrackedTopologyAware
- Parameters:
- topologyName- the name of the topology to use
- conf- the config for the topology
- topology- the topology itself.
- submitOpts- options for topology
- Returns:
- an AutoCloseable that will kill the topology.
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
submitTopologyWithOptspublic void submitTopologyWithOpts(String name, 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
 
- 
uploadNewCredentialspublic void uploadNewCredentials(String topologyName, Credentials creds) throws org.apache.storm.thrift.TException Description copied from interface:ILocalClusterUpload new credentials to a topology.- Specified by:
- uploadNewCredentialsin interface- ILocalCluster
- Specified by:
- uploadNewCredentialsin interface- Nimbus.Iface
- Parameters:
- topologyName- the name of the topology
- creds- the new credentails for the topology.
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
killTopologyDescription copied from interface:ILocalClusterKill a topology (if you are not using ILocalTopology).- Specified by:
- killTopologyin interface- ILocalCluster
- Specified by:
- killTopologyin interface- Nimbus.Iface
- Parameters:
- topologyName- the name of the topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
killTopologyWithOptspublic void killTopologyWithOpts(String name, KillOptions options) throws org.apache.storm.thrift.TException Description copied from interface:ILocalClusterKill a topology (if you are not using ILocalTopology).- Specified by:
- killTopologyWithOptsin interface- ILocalCluster
- Specified by:
- killTopologyWithOptsin interface- Nimbus.Iface
- Parameters:
- name- the name of the topology
- options- for how to kill the topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
activateDescription copied from interface:ILocalClusterActivate a topology.- Specified by:
- activatein interface- ILocalCluster
- Specified by:
- activatein interface- Nimbus.Iface
- Parameters:
- topologyName- the name of the topology to activate
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
deactivateDescription copied from interface:ILocalClusterDeactivate a topology.- Specified by:
- deactivatein interface- ILocalCluster
- Specified by:
- deactivatein interface- Nimbus.Iface
- Parameters:
- topologyName- the name of the topology to deactivate
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
rebalancepublic void rebalance(String name, RebalanceOptions options) throws org.apache.storm.thrift.TException Description copied from interface:ILocalClusterRebalance a topology.- Specified by:
- rebalancein interface- ILocalCluster
- Specified by:
- rebalancein interface- Nimbus.Iface
- Parameters:
- name- the name of the topology
- options- options for rebalanceing the topology.
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
shutdownpublic void shutdown()Description copied from interface:ILocalClusterShut down the cluster.- Specified by:
- shutdownin interface- ILocalCluster
 
- 
getTopologyConfDescription copied from interface:ILocalClusterThe config of a topology as a JSON string.- Specified by:
- getTopologyConfin interface- ILocalCluster
- Specified by:
- getTopologyConfin interface- Nimbus.Iface
- Parameters:
- id- the id of the topology (not the name)
- Returns:
- The config of a topology as a JSON string
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getTopologyDescription copied from interface:ILocalClusterGet the compiled storm topology.- Specified by:
- getTopologyin interface- ILocalCluster
- Specified by:
- getTopologyin interface- Nimbus.Iface
- Parameters:
- id- the id of the topology (not the name)
- Returns:
- the compiled storm topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getClusterInfoDescription copied from interface:ILocalClusterGet cluster information.- Specified by:
- getClusterInfoin interface- ILocalCluster
- Specified by:
- getClusterInfoin interface- Nimbus.Iface
- Returns:
- a summary of the current state of the cluster
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getTopologySummaries- Specified by:
- getTopologySummariesin interface- ILocalCluster
- Specified by:
- getTopologySummariesin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getTopologySummaryByNamepublic TopologySummary getTopologySummaryByName(String name) throws org.apache.storm.thrift.TException - Specified by:
- getTopologySummaryByNamein interface- ILocalCluster
- Specified by:
- getTopologySummaryByNamein interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getTopologySummary- Specified by:
- getTopologySummaryin interface- ILocalCluster
- Specified by:
- getTopologySummaryin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
- 
getTopologyInfoDescription copied from interface:ILocalClusterGet the state of a topology.- Specified by:
- getTopologyInfoin interface- ILocalCluster
- Specified by:
- getTopologyInfoin interface- Nimbus.Iface
- Parameters:
- id- the id of the topology (not the name)
- Returns:
- the state of a topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getTopologyInfoByNameDescription copied from interface:ILocalClusterGet the state of a topology.- Specified by:
- getTopologyInfoByNamein interface- ILocalCluster
- Specified by:
- getTopologyInfoByNamein interface- Nimbus.Iface
- Parameters:
- name- the name of the topology (not the id)
- Returns:
- the state of a topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getTopologyInfoWithOptspublic TopologyInfo getTopologyInfoWithOpts(String id, GetInfoOptions options) throws org.apache.storm.thrift.TException Description copied from interface:ILocalClusterGet the state of a topology.- Specified by:
- getTopologyInfoWithOptsin interface- ILocalCluster
- Specified by:
- getTopologyInfoWithOptsin interface- Nimbus.Iface
- Parameters:
- id- the id of the topology (not the name)
- options- This is to choose number of Error(s) in TopologyInfo.
- Returns:
- the state of a topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getTopologyInfoByNameWithOptspublic TopologyInfo getTopologyInfoByNameWithOpts(String name, GetInfoOptions options) throws org.apache.storm.thrift.TException Description copied from interface:ILocalClusterGet the state of a topology.- Specified by:
- getTopologyInfoByNameWithOptsin interface- ILocalCluster
- Specified by:
- getTopologyInfoByNameWithOptsin interface- Nimbus.Iface
- Parameters:
- name- the name of the topology (not the id)
- options- This is GetInfoOptions to choose Error(s) in on TopologyInfo.
- Returns:
- the state of a topology
- Throws:
- org.apache.storm.thrift.TException- on any error from nimbus
 
- 
getThriftServerPortpublic int getThriftServerPort()
- 
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
 
- 
close- Specified by:
- closein interface- AutoCloseable
- Throws:
- Exception
 
- 
getSupervisorGet a specific Supervisor. This is intended mostly for internal testing.- Parameters:
- id- the id of the supervisor
 
- 
killSupervisorKill a specific supervisor. This is intended mostly for internal testing.- Parameters:
- id- the id of the supervisor
 
- 
addSupervisorAdd another supervisor to the topology. This is intended mostly for internal testing.- Throws:
- Exception
 
- 
addSupervisorAdd another supervisor to the topology. This is intended mostly for internal testing.- Parameters:
- ports- the number of ports/slots the supervisor should have
- Throws:
- Exception
 
- 
addSupervisorAdd another supervisor to the topology. This is intended mostly for internal testing.- Parameters:
- ports- the number of ports/slots the supervisor should have
- id- the id of the new supervisor, so you can find it later.
- Throws:
- Exception
 
- 
addSupervisorAdd another supervisor to the topology. This is intended mostly for internal testing.- Parameters:
- ports- the number of ports/slots the supervisor should have
- conf- any config values that should be added/over written in the daemon conf of the cluster.
- id- the id of the new supervisor, so you can find it later.
- Throws:
- Exception
 
- 
waitForIdleWait for the cluster to be idle. This is intended to be used with Simulated time and is for internal testing. Note that this does not wait for spout or bolt executors to be idle.- Throws:
- InterruptedException- if interrupted while waiting.
- AssertionError- if the cluster did not come to an idle point with a timeout.
 
- 
waitForIdleWait for the cluster to be idle. This is intended to be used with Simulated time and is for internal testing. Note that this does not wait for spout or bolt executors to be idle.- Parameters:
- timeoutMs- the number of ms to wait before throwing an error.
- Throws:
- InterruptedException- if interrupted while waiting.
- AssertionError- if the cluster did not come to an idle point with a timeout.
 
- 
advanceClusterTimeDescription copied from interface:ILocalClusterAdvance the cluster time when the cluster is using SimulatedTime. This is intended for internal testing only.- Specified by:
- advanceClusterTimein interface- ILocalCluster
- Parameters:
- secs- the number of seconds to advance time
- Throws:
- InterruptedException
 
- 
advanceClusterTimeDescription copied from interface:ILocalClusterAdvance the cluster time when the cluster is using SimulatedTime. This is intended for internal testing only.- Specified by:
- advanceClusterTimein interface- ILocalCluster
- Parameters:
- secs- the number of seconds to advance time
- incSecs- the number of steps we should take when advancing simulated time
- Throws:
- InterruptedException
 
- 
getClusterStateDescription copied from interface:ILocalClusterThis is intended for internal testing only.- Specified by:
- getClusterStatein interface- ILocalCluster
- Returns:
- an internal class that holds the state of the cluster.
 
- 
getTrackedIdDescription copied from interface:ILocalClusterIf the cluster is tracked get the id for the tracked cluster. This is intended for internal testing only.- Specified by:
- getTrackedIdin interface- ILocalCluster
- Returns:
- the id of the tracked cluster
 
- 
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 name, String component, 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 id, 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
 
- 
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, org.apache.storm.thrift.TException - Specified by:
- deleteBlobin interface- Nimbus.Iface
- Throws:
- AuthorizationException
- KeyNotFoundException
- 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
 
- 
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
 
- 
getTopologyPageInfopublic TopologyPageInfo getTopologyPageInfo(String id, String window, boolean isIncludeSys) 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 id, String host, boolean isIncludeSys) 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 topologyId, String componentId, String window, boolean isIncludeSys) throws NotAliveException, AuthorizationException, org.apache.storm.thrift.TException - Specified by:
- getComponentPageInfoin 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
 
- 
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 node) 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 heatbeat) 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
 
- 
processWorkerMetrics- Specified by:
- processWorkerMetricsin interface- Nimbus.Iface
- Throws:
- org.apache.storm.thrift.TException
 
 
-