Uses of Class
org.apache.storm.generated.InvalidTopologyException
Package
Description
ElasticSearch examples classes.
ElasticSearch Trident example classes.
-
Uses of InvalidTopologyException in org.apache.storm
Modifier and TypeMethodDescriptionstatic 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.void
LocalCluster.submitTopology
(String name, String uploadedJarLocation, String jsonConf, StormTopology 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.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. -
Uses of InvalidTopologyException in org.apache.storm.container.oci
-
Uses of InvalidTopologyException in org.apache.storm.daemon
Modifier and TypeMethodDescriptionstatic int
StormCommon.numStartExecutors
(Object component) StormCommon.stormTaskInfo
(StormTopology userTopology, Map<String, Object> topoConf) 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) -
Uses of InvalidTopologyException in org.apache.storm.daemon.nimbus
Modifier and TypeMethodDescriptionvoid
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) -
Uses of InvalidTopologyException in org.apache.storm.daemon.worker
ModifierConstructorDescriptionWorkerState
(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) -
Uses of InvalidTopologyException in org.apache.storm.elasticsearch.bolt
-
Uses of InvalidTopologyException in org.apache.storm.elasticsearch.trident
-
Uses of InvalidTopologyException in org.apache.storm.generated
Modifier and TypeMethodDescriptionInvalidTopologyException.deepCopy()
Nimbus.rebalance_result.get_ite()
Nimbus.submitTopology_result.get_ite()
Nimbus.submitTopologyWithOpts_result.get_ite()
Nimbus.uploadNewCredentials_result.get_ite()
Modifier and TypeMethodDescriptionint
InvalidTopologyException.compareTo
(InvalidTopologyException other) boolean
InvalidTopologyException.equals
(InvalidTopologyException that) void
Nimbus.rebalance_result.set_ite
(InvalidTopologyException ite) void
Nimbus.submitTopology_result.set_ite
(InvalidTopologyException ite) void
Nimbus.submitTopologyWithOpts_result.set_ite
(InvalidTopologyException ite) void
Nimbus.uploadNewCredentials_result.set_ite
(InvalidTopologyException ite) Modifier and TypeMethodDescriptionNimbus.AsyncClient.rebalance_call.getResult()
Nimbus.AsyncClient.submitTopology_call.getResult()
Nimbus.AsyncClient.submitTopologyWithOpts_call.getResult()
Nimbus.AsyncClient.uploadNewCredentials_call.getResult()
void
Nimbus.Client.rebalance
(String name, RebalanceOptions options) void
Nimbus.Iface.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.Client.submitTopology
(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) void
Nimbus.Iface.submitTopology
(String name, String uploadedJarLocation, String jsonConf, StormTopology topology) void
Nimbus.Client.submitTopologyWithOpts
(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) void
Nimbus.Iface.submitTopologyWithOpts
(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options) void
Nimbus.Client.uploadNewCredentials
(String name, Credentials creds) void
Nimbus.Iface.uploadNewCredentials
(String name, Credentials creds) ModifierConstructorDescriptionPerforms a deep copy on other.submitTopology_result
(AlreadyAliveException e, InvalidTopologyException ite, AuthorizationException aze) submitTopologyWithOpts_result
(AlreadyAliveException e, InvalidTopologyException ite, AuthorizationException aze) uploadNewCredentials_result
(NotAliveException e, InvalidTopologyException ite, AuthorizationException aze) -
Uses of InvalidTopologyException in org.apache.storm.kafka.trident
-
Uses of InvalidTopologyException in org.apache.storm.nimbus
Modifier and TypeMethodDescriptionvoid
DefaultTopologyValidator.validate
(String topologyName, Map topologyConf, StormTopology topology) void
ITopologyValidator.validate
(String topologyName, Map<String, Object> topologyConf, StormTopology topology) void
StrictTopologyValidator.validate
(String topologyName, Map topologyConf, StormTopology topology) -
Uses of InvalidTopologyException in org.apache.storm.utils
Modifier and TypeClassDescriptionclass
Wraps the generated TException to allow getMessage() to return a valid string.Modifier and TypeMethodDescriptionstatic int
ServerUtils.getComponentParallelism
(Map<String, Object> topoConf, Object component) 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)