Package | Description |
---|---|
org.apache.storm | |
org.apache.storm.container.oci | |
org.apache.storm.daemon | |
org.apache.storm.daemon.nimbus | |
org.apache.storm.daemon.worker | |
org.apache.storm.elasticsearch.bolt |
ElasticSearch examples classes.
|
org.apache.storm.elasticsearch.trident |
ElasticSearch Trident example classes.
|
org.apache.storm.generated | |
org.apache.storm.kafka.trident | |
org.apache.storm.nimbus | |
org.apache.storm.utils |
Modifier and Type | Method and Description |
---|---|
static boolean |
StormSubmitter.pushCredentials(String name,
Map<String,Object> topoConf,
Map<String,String> credentials)
Push a new set of credentials to the running topology.
|
static boolean |
StormSubmitter.pushCredentials(String name,
Map<String,Object> topoConf,
Map<String,String> credentials,
String expectedUser)
Push a new set of credentials to the running topology.
|
static void |
StormSubmitter.submitTopology(String name,
Map<String,Object> topoConf,
StormTopology topology)
Submits a topology to run on the cluster.
|
static void |
StormSubmitter.submitTopology(String name,
Map<String,Object> topoConf,
StormTopology topology,
SubmitOptions opts)
Submits a topology to run on the cluster.
|
static void |
StormSubmitter.submitTopology(String name,
Map<String,Object> topoConf,
StormTopology topology,
SubmitOptions opts,
StormSubmitter.ProgressListener progressListener)
Submits a topology to run on the cluster.
|
void |
LocalCluster.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology) |
static void |
StormSubmitter.submitTopologyAs(String name,
Map<String,Object> topoConf,
StormTopology topology,
SubmitOptions opts,
StormSubmitter.ProgressListener progressListener,
String asUser)
Submits a topology to run on the cluster as a particular user.
|
void |
LocalCluster.submitTopologyWithOpts(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
SubmitOptions options) |
static void |
StormSubmitter.submitTopologyWithProgressBar(String name,
Map<String,Object> topoConf,
StormTopology topology)
Submits a topology to run on the cluster with a progress bar.
|
static void |
StormSubmitter.submitTopologyWithProgressBar(String name,
Map<String,Object> topoConf,
StormTopology topology,
SubmitOptions opts)
Submits a topology to run on the cluster with a progress bar.
|
Modifier and Type | Method and Description |
---|---|
static void |
OciUtils.adjustImageConfigForTopo(Map<String,Object> conf,
Map<String,Object> topoConf,
String topoId)
Adjust the image config for the topology.
|
Modifier and Type | Method and Description |
---|---|
static int |
StormCommon.numStartExecutors(Object component) |
static Map<Integer,String> |
StormCommon.stormTaskInfo(StormTopology userTopology,
Map<String,Object> topoConf) |
protected Map<Integer,String> |
StormCommon.stormTaskInfoImpl(StormTopology userTopology,
Map<String,Object> topoConf) |
static StormTopology |
StormCommon.systemTopology(Map<String,Object> topoConf,
StormTopology topology)
Construct a new topology structure after adding system components and streams.
|
protected StormTopology |
StormCommon.systemTopologyImpl(Map<String,Object> topoConf,
StormTopology topology) |
static void |
StormCommon.validateBasic(StormTopology topology) |
static void |
StormCommon.validateStructure(StormTopology topology) |
Modifier and Type | Method and Description |
---|---|
void |
Nimbus.rebalance(String topoName,
RebalanceOptions options) |
void |
Nimbus.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology) |
void |
Nimbus.submitTopologyWithOpts(String topoName,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
SubmitOptions options) |
void |
Nimbus.uploadNewCredentials(String topoName,
Credentials credentials) |
Constructor and Description |
---|
WorkerState(Map<String,Object> conf,
IContext mqContext,
String topologyId,
String assignmentId,
Supplier<SupervisorIfaceFactory> supervisorIfaceSupplier,
int port,
String workerId,
Map<String,Object> topologyConf,
IStateStorage stateStorage,
IStormClusterState stormClusterState,
Collection<IAutoCredentials> autoCredentials,
StormMetricRegistry metricRegistry,
Credentials initialCredentials) |
Modifier and Type | Method and Description |
---|---|
static void |
EsIndexTopology.main(String[] args)
The example’s main method.
|
Modifier and Type | Method and Description |
---|---|
static void |
TridentEsTopology.main(String[] args)
The example’s main method.
|
Modifier and Type | Method and Description |
---|---|
InvalidTopologyException |
InvalidTopologyException.deepCopy() |
InvalidTopologyException |
Nimbus.submitTopology_result.get_ite() |
InvalidTopologyException |
Nimbus.submitTopologyWithOpts_result.get_ite() |
InvalidTopologyException |
Nimbus.rebalance_result.get_ite() |
InvalidTopologyException |
Nimbus.uploadNewCredentials_result.get_ite() |
Modifier and Type | Method and Description |
---|---|
int |
InvalidTopologyException.compareTo(InvalidTopologyException other) |
boolean |
InvalidTopologyException.equals(InvalidTopologyException that) |
void |
Nimbus.submitTopology_result.set_ite(InvalidTopologyException ite) |
void |
Nimbus.submitTopologyWithOpts_result.set_ite(InvalidTopologyException ite) |
void |
Nimbus.rebalance_result.set_ite(InvalidTopologyException ite) |
void |
Nimbus.uploadNewCredentials_result.set_ite(InvalidTopologyException ite) |
Modifier and Type | Method and Description |
---|---|
Void |
Nimbus.AsyncClient.submitTopology_call.getResult() |
Void |
Nimbus.AsyncClient.submitTopologyWithOpts_call.getResult() |
Void |
Nimbus.AsyncClient.rebalance_call.getResult() |
Void |
Nimbus.AsyncClient.uploadNewCredentials_call.getResult() |
void |
Nimbus.Iface.rebalance(String name,
RebalanceOptions options) |
void |
Nimbus.Client.rebalance(String name,
RebalanceOptions options) |
void |
Nimbus.Client.recv_rebalance() |
void |
Nimbus.Client.recv_submitTopology() |
void |
Nimbus.Client.recv_submitTopologyWithOpts() |
void |
Nimbus.Client.recv_uploadNewCredentials() |
void |
Nimbus.Iface.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology) |
void |
Nimbus.Client.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology) |
void |
Nimbus.Iface.submitTopologyWithOpts(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
SubmitOptions options) |
void |
Nimbus.Client.submitTopologyWithOpts(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
SubmitOptions options) |
void |
Nimbus.Iface.uploadNewCredentials(String name,
Credentials creds) |
void |
Nimbus.Client.uploadNewCredentials(String name,
Credentials creds) |
Constructor and Description |
---|
InvalidTopologyException(InvalidTopologyException other)
Performs a deep copy on other.
|
rebalance_result(NotAliveException e,
InvalidTopologyException ite,
AuthorizationException aze) |
submitTopology_result(AlreadyAliveException e,
InvalidTopologyException ite,
AuthorizationException aze) |
submitTopologyWithOpts_result(AlreadyAliveException e,
InvalidTopologyException ite,
AuthorizationException aze) |
uploadNewCredentials_result(NotAliveException e,
InvalidTopologyException ite,
AuthorizationException aze) |
Modifier and Type | Method and Description |
---|---|
protected void |
TridentKafkaClientTopologyNamedTopics.run(String[] args) |
Modifier and Type | Method and Description |
---|---|
void |
ITopologyValidator.validate(String topologyName,
Map<String,Object> topologyConf,
StormTopology topology) |
void |
StrictTopologyValidator.validate(String topologyName,
Map topologyConf,
StormTopology topology) |
void |
DefaultTopologyValidator.validate(String topologyName,
Map topologyConf,
StormTopology topology) |
Modifier and Type | Class and Description |
---|---|
class |
WrappedInvalidTopologyException
Wraps the generated TException to allow getMessage() to return a valid string.
|
Modifier and Type | Method and Description |
---|---|
static int |
ServerUtils.getComponentParallelism(Map<String,Object> topoConf,
Object component) |
static Map<String,Integer> |
ServerUtils.getComponentParallelism(Map<String,Object> topoConf,
StormTopology topology) |
static double |
ServerUtils.getEstimatedTotalHeapMemoryRequiredByTopo(Map<String,Object> topoConf,
StormTopology topology) |
static int |
ServerUtils.getEstimatedWorkerCountForRasTopo(Map<String,Object> topoConf,
StormTopology topology) |
static void |
Utils.validateCycleFree(StormTopology topology,
String name)
Validate that the topology is cycle free.
|
static void |
ServerUtils.validateTopologyAckerBundleResource(Map<String,Object> topoConf,
StormTopology topology,
String topoName)
RAS scheduler will try to distribute ackers evenly over workers by adding some ackers to each newly launched worker.
|
static void |
Utils.validateTopologyBlobStoreMap(Map<String,Object> topoConf)
Validate topology blobstore map.
|
static void |
Utils.validateTopologyBlobStoreMap(Map<String,Object> topoConf,
BlobStore blobStore)
Validate topology blobstore map.
|
static void |
Utils.validateTopologyBlobStoreMap(Map<String,Object> topoConf,
NimbusBlobStore client)
Validate topology blobstore map.
|
static void |
ServerUtils.validateTopologyWorkerMaxHeapSizeConfigs(Map<String,Object> stormConf,
StormTopology topology,
double defaultWorkerMaxHeapSizeMb) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.