Uses of Class
org.apache.storm.generated.InvalidTopologyException
-
-
Uses of InvalidTopologyException in org.apache.storm
Methods in org.apache.storm that throw InvalidTopologyException Modifier and Type Method 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.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
Methods in org.apache.storm.container.oci that throw InvalidTopologyException Modifier and Type Method Description static void
OciUtils. adjustImageConfigForTopo(Map<String,Object> conf, Map<String,Object> topoConf, String topoId)
Adjust the image config for the topology. -
Uses of InvalidTopologyException in org.apache.storm.daemon
Methods in org.apache.storm.daemon that throw InvalidTopologyException Modifier and Type Method 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)
-
Uses of InvalidTopologyException in org.apache.storm.daemon.nimbus
Methods in org.apache.storm.daemon.nimbus that throw InvalidTopologyException Modifier and Type Method 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)
-
Uses of InvalidTopologyException in org.apache.storm.daemon.worker
Constructors in org.apache.storm.daemon.worker that throw InvalidTopologyException Constructor 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)
-
Uses of InvalidTopologyException in org.apache.storm.generated
Methods in org.apache.storm.generated that return InvalidTopologyException Modifier and Type Method Description InvalidTopologyException
InvalidTopologyException. deepCopy()
InvalidTopologyException
Nimbus.rebalance_result. get_ite()
InvalidTopologyException
Nimbus.submitTopology_result. get_ite()
InvalidTopologyException
Nimbus.submitTopologyWithOpts_result. get_ite()
InvalidTopologyException
Nimbus.uploadNewCredentials_result. get_ite()
Methods in org.apache.storm.generated with parameters of type InvalidTopologyException Modifier and Type Method Description int
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)
Methods in org.apache.storm.generated that throw InvalidTopologyException Modifier and Type Method Description Void
Nimbus.AsyncClient.rebalance_call. getResult()
Void
Nimbus.AsyncClient.submitTopology_call. getResult()
Void
Nimbus.AsyncClient.submitTopologyWithOpts_call. getResult()
Void
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)
Constructors in org.apache.storm.generated with parameters of type InvalidTopologyException Constructor 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)
-
Uses of InvalidTopologyException in org.apache.storm.kafka.trident
Methods in org.apache.storm.kafka.trident that throw InvalidTopologyException Modifier and Type Method Description protected void
TridentKafkaClientTopologyNamedTopics. run(String[] args)
-
Uses of InvalidTopologyException in org.apache.storm.nimbus
Methods in org.apache.storm.nimbus that throw InvalidTopologyException Modifier and Type Method Description void
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
Subclasses of InvalidTopologyException in org.apache.storm.utils Modifier and Type Class Description class
WrappedInvalidTopologyException
Wraps the generated TException to allow getMessage() to return a valid string.Methods in org.apache.storm.utils that throw InvalidTopologyException Modifier and Type Method 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)
-