Uses of Class
org.apache.storm.generated.StormTopology
- 
- 
Uses of StormTopology in org.apache.stormSubclasses of StormTopology in org.apache.storm Modifier and Type Class Description classLocalCluster.LocalTopologyWhen running a topology locally, for tests etc.Methods in org.apache.storm that return StormTopology Modifier and Type Method Description static StormTopologyThrift. buildTopology(HashMap<String,Thrift.SpoutDetails> spoutMap, HashMap<String,Thrift.BoltDetails> boltMap, HashMap<String,StateSpoutSpec> stateMap)static StormTopologyThrift. buildTopology(Map<String,Thrift.SpoutDetails> spoutMap, Map<String,Thrift.BoltDetails> boltMap)static StormTopologyExclamationTopology. getStormTopology()StormTopologyILocalCluster. getTopology(String id)Get the compiled storm topology.StormTopologyLocalCluster. getTopology(String id)StormTopologyLocalCluster. getUserTopology(String id)Methods in org.apache.storm that return types with arguments of type StormTopology Modifier and Type Method Description static Testing.CapturedTopology<StormTopology>Testing. captureTopology(StormTopology topology)Rewrites a topology so that all the tuples flowing through it are captured.Methods in org.apache.storm with parameters of type StormTopology Modifier and Type Method Description static Testing.CapturedTopology<StormTopology>Testing. captureTopology(StormTopology topology)Rewrites a topology so that all the tuples flowing through it are captured.static Map<String,List<FixedTuple>>Testing. completeTopology(ILocalCluster cluster, StormTopology topology)Run a topology to completion capturing all of the messages that are emitted.static Map<String,List<FixedTuple>>Testing. completeTopology(ILocalCluster cluster, StormTopology topology, CompleteTopologyParam param)Run a topology to completion capturing all of the messages that are emitted.static TrackedTopologyTesting. mkTrackedTopology(ILocalCluster cluster, StormTopology topology)Deprecated.useTrackedTopologydirectly.voidISubmitterHook. notify(TopologyInfo topologyInfo, Map<String,Object> topoConf, StormTopology topology)ILocalCluster.ILocalTopologyILocalCluster. submitTopology(String topologyName, Map<String,Object> conf, StormTopology topology)Submit a topology to be run in local mode.voidLocalCluster. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)LocalCluster.LocalTopologyLocalCluster. submitTopology(String topologyName, Map<String,Object> conf, StormTopology topology)static voidStormSubmitter. submitTopology(String name, Map<String,Object> topoConf, StormTopology topology)Submits a topology to run on the cluster.static voidStormSubmitter. submitTopology(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts)Submits a topology to run on the cluster.static voidStormSubmitter. submitTopology(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts, StormSubmitter.ProgressListener progressListener)Submits a topology to run on the cluster.static voidStormSubmitter. 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.ILocalCluster.ILocalTopologyILocalCluster. submitTopologyWithOpts(String topologyName, Map<String,Object> conf, StormTopology topology, SubmitOptions submitOpts)Submit a topology to be run in local mode.voidLocalCluster. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)LocalCluster.LocalTopologyLocalCluster. submitTopologyWithOpts(String topologyName, Map<String,Object> conf, StormTopology topology, SubmitOptions submitOpts)static voidStormSubmitter. submitTopologyWithProgressBar(String name, Map<String,Object> topoConf, StormTopology topology)Submits a topology to run on the cluster with a progress bar.static voidStormSubmitter. submitTopologyWithProgressBar(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts)Submits a topology to run on the cluster with a progress bar.static Testing.CapturedTopology<TrackedTopology>Testing. trackAndCaptureTopology(ILocalCluster cluster, StormTopology topology)Track and capture a topology.Constructors in org.apache.storm with parameters of type StormTopology Constructor Description LocalTopology(String topoName, StormTopology topo)
- 
Uses of StormTopology in org.apache.storm.daemonMethods in org.apache.storm.daemon that return StormTopology Modifier and Type Method Description static StormTopologyStormCommon. systemTopology(Map<String,Object> topoConf, StormTopology topology)Construct a new topology structure after adding system components and streams.protected StormTopologyStormCommon. systemTopologyImpl(Map<String,Object> topoConf, StormTopology topology)Methods in org.apache.storm.daemon with parameters of type StormTopology Modifier and Type Method Description static Map<GlobalStreamId,Grouping>StormCommon. ackerInputs(StormTopology topology)static voidStormCommon. addAcker(Map<String,Object> conf, StormTopology topology)static voidStormCommon. addEventLogger(Map<String,Object> conf, StormTopology topology)static voidStormCommon. addMetricComponents(Map<String,Object> conf, StormTopology topology)static voidStormCommon. addMetricStreams(StormTopology topology)static voidStormCommon. addSystemComponents(Map<String,Object> conf, StormTopology topology)static voidStormCommon. addSystemStreams(StormTopology topology)static Map<String,Object>StormCommon. allComponents(StormTopology topology)static Map<GlobalStreamId,Grouping>StormCommon. eventLoggerInputs(StormTopology topology)static Map<String,Bolt>StormCommon. metricsConsumerBoltSpecs(Map<String,Object> conf, StormTopology topology)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 StormTopologyStormCommon. systemTopology(Map<String,Object> topoConf, StormTopology topology)Construct a new topology structure after adding system components and streams.protected StormTopologyStormCommon. systemTopologyImpl(Map<String,Object> topoConf, StormTopology topology)static voidStormCommon. validateBasic(StormTopology topology)static voidStormCommon. validateStructure(StormTopology topology)
- 
Uses of StormTopology in org.apache.storm.daemon.nimbusMethods in org.apache.storm.daemon.nimbus that return StormTopology Modifier and Type Method Description StormTopologyNimbus. getTopology(String id)StormTopologyNimbus. getUserTopology(String id)StormTopologyTopoCache. readTopology(String topoId, Subject who)Read a topology.Methods in org.apache.storm.daemon.nimbus with parameters of type StormTopology Modifier and Type Method Description voidTopoCache. addTopology(String topoId, Subject who, StormTopology topo)Add a new topology.voidNimbus. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)voidNimbus. submitTopologyWithOpts(String topoName, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)voidTopoCache. updateTopology(String topoId, Subject who, StormTopology topo)Update an existing topology .
- 
Uses of StormTopology in org.apache.storm.daemon.uiMethods in org.apache.storm.daemon.ui with parameters of type StormTopology Modifier and Type Method Description static Map<String,List<ExecutorSummary>>UIHelpers. getBoltExecutors(List<ExecutorSummary> executorSummaries, StormTopology stormTopology, boolean sys)getBoltExecutors.static Map<String,List<ExecutorSummary>>UIHelpers. getSpoutExecutors(List<ExecutorSummary> executorSummaries, StormTopology stormTopology)getSpoutExecutors.static Map<String,Map<String,Object>>UIHelpers. getTopologyLag(StormTopology userTopology, Map<String,Object> config)getTopologyLag.
- 
Uses of StormTopology in org.apache.storm.daemon.workerMethods in org.apache.storm.daemon.worker that return StormTopology Modifier and Type Method Description StormTopologyWorkerState. getSystemTopology()StormTopologyWorkerState. getTopology()
- 
Uses of StormTopology in org.apache.storm.drpcMethods in org.apache.storm.drpc that return StormTopology Modifier and Type Method Description StormTopologyLinearDRPCTopologyBuilder. createLocalTopology(ILocalDRPC drpc)StormTopologyLinearDRPCTopologyBuilder. createRemoteTopology()
- 
Uses of StormTopology in org.apache.storm.fluxMethods in org.apache.storm.flux that return StormTopology Modifier and Type Method Description static StormTopologyFluxBuilder. buildTopology(ExecutionContext context)Given a topology definition, return a Storm topology that can be run either locally or remotely.
- 
Uses of StormTopology in org.apache.storm.flux.apiMethods in org.apache.storm.flux.api that return StormTopology Modifier and Type Method Description StormTopologyTopologySource. getTopology(Map<String,Object> config)
- 
Uses of StormTopology in org.apache.storm.generatedMethods in org.apache.storm.generated that return StormTopology Modifier and Type Method Description StormTopologyStormTopology. deepCopy()StormTopologyNimbus.getTopology_result. get_success()StormTopologyNimbus.getUserTopology_result. get_success()StormTopologyNimbus.submitTopology_args. get_topology()StormTopologyNimbus.submitTopologyWithOpts_args. get_topology()StormTopologyNimbus.AsyncClient.getTopology_call. getResult()StormTopologyNimbus.AsyncClient.getUserTopology_call. getResult()StormTopologyNimbus.Client. getTopology(String id)StormTopologyNimbus.Iface. getTopology(String id)Returns the compiled topology that contains ackers and metrics consumsers.StormTopologyNimbus.Client. getUserTopology(String id)StormTopologyNimbus.Iface. getUserTopology(String id)Returns the user specified topology as submitted originally.StormTopologyNimbus.Client. recv_getTopology()StormTopologyNimbus.Client. recv_getUserTopology()Methods in org.apache.storm.generated that return types with arguments of type StormTopology Modifier and Type Method Description org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology>Nimbus.AsyncProcessor.getTopology. getResultHandler(org.apache.storm.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer fb, int seqid)org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology>Nimbus.AsyncProcessor.getUserTopology. getResultHandler(org.apache.storm.thrift.server.AbstractNonblockingServer.AsyncFrameBuffer fb, int seqid)Methods in org.apache.storm.generated with parameters of type StormTopology Modifier and Type Method Description intStormTopology. compareTo(StormTopology other)booleanStormTopology. equals(StormTopology that)voidNimbus.Client. send_submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)voidNimbus.Client. send_submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)voidNimbus.getTopology_result. set_success(StormTopology success)voidNimbus.getUserTopology_result. set_success(StormTopology success)voidNimbus.submitTopology_args. set_topology(StormTopology topology)voidNimbus.submitTopologyWithOpts_args. set_topology(StormTopology topology)voidNimbus.AsyncClient. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)voidNimbus.AsyncIface. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)voidNimbus.Client. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)voidNimbus.Iface. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)voidNimbus.AsyncClient. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)voidNimbus.AsyncIface. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)voidNimbus.Client. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)voidNimbus.Iface. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)Method parameters in org.apache.storm.generated with type arguments of type StormTopology Modifier and Type Method Description voidNimbus.AsyncClient. getTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)voidNimbus.AsyncIface. getTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)voidNimbus.AsyncClient. getUserTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)voidNimbus.AsyncIface. getUserTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)voidNimbus.AsyncProcessor.getTopology. start(I iface, Nimbus.getTopology_args args, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)voidNimbus.AsyncProcessor.getUserTopology. start(I iface, Nimbus.getUserTopology_args args, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)Constructors in org.apache.storm.generated with parameters of type StormTopology Constructor Description getTopology_result(StormTopology success, NotAliveException e, AuthorizationException aze)getUserTopology_result(StormTopology success, NotAliveException e, AuthorizationException aze)StormTopology(StormTopology other)Performs a deep copy on other.submitTopology_args(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)submitTopology_call(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.storm.thrift.async.TAsyncClient client, org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory, org.apache.storm.thrift.transport.TNonblockingTransport transport)submitTopologyWithOpts_args(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)submitTopologyWithOpts_call(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler, org.apache.storm.thrift.async.TAsyncClient client, org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory, org.apache.storm.thrift.transport.TNonblockingTransport transport)Constructor parameters in org.apache.storm.generated with type arguments of type StormTopology Constructor Description getTopology_call(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler, org.apache.storm.thrift.async.TAsyncClient client, org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory, org.apache.storm.thrift.transport.TNonblockingTransport transport)getUserTopology_call(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler, org.apache.storm.thrift.async.TAsyncClient client, org.apache.storm.thrift.protocol.TProtocolFactory protocolFactory, org.apache.storm.thrift.transport.TNonblockingTransport transport)
- 
Uses of StormTopology in org.apache.storm.hdfs.tridentMethods in org.apache.storm.hdfs.trident that return StormTopology Modifier and Type Method Description static StormTopologyTridentFileTopology. buildTopology(String hdfsUrl)static StormTopologyTridentSequenceTopology. buildTopology(String hdfsUrl)
- 
Uses of StormTopology in org.apache.storm.hive.tridentMethods in org.apache.storm.hive.trident that return StormTopology Modifier and Type Method Description static StormTopologyTridentHiveTopology. buildTopology(String metaStoreUri, String dbName, String tblName, Object keytab, Object principal)
- 
Uses of StormTopology in org.apache.storm.jdbc.topologyMethods in org.apache.storm.jdbc.topology that return StormTopology Modifier and Type Method Description abstract StormTopologyAbstractUserTopology. getTopology()StormTopologyUserPersistenceTopology. getTopology()StormTopologyUserPersistenceTridentTopology. getTopology()
- 
Uses of StormTopology in org.apache.storm.kafka.boltMethods in org.apache.storm.kafka.bolt that return StormTopology Modifier and Type Method Description static StormTopologyKafkaProducerTopology. newTopology(String brokerUrl, String topicName)Create a new topology that writes random UUIDs to Kafka.
- 
Uses of StormTopology in org.apache.storm.kafka.spoutMethods in org.apache.storm.kafka.spout that return StormTopology Modifier and Type Method Description protected StormTopologyKafkaSpoutTopologyMainNamedTopics. getTopologyKafkaSpout(KafkaSpoutConfig<String,String> spoutConfig)protected StormTopologyKafkaSpoutTopologyMainWildcardTopics. getTopologyKafkaSpout(KafkaSpoutConfig<String,String> spoutConfig)
- 
Uses of StormTopology in org.apache.storm.kafka.tridentMethods in org.apache.storm.kafka.trident that return StormTopology Modifier and Type Method Description static StormTopologyTridentKafkaConsumerTopology. newTopology(ITridentDataSource tridentSpout)Creates a new topology that prints inputs to stdout.
- 
Uses of StormTopology in org.apache.storm.nimbusMethods in org.apache.storm.nimbus with parameters of type StormTopology Modifier and Type Method Description voidDefaultTopologyValidator. validate(String topologyName, Map topologyConf, StormTopology topology)voidITopologyValidator. validate(String topologyName, Map<String,Object> topologyConf, StormTopology topology)voidStrictTopologyValidator. validate(String topologyName, Map topologyConf, StormTopology topology)
- 
Uses of StormTopology in org.apache.storm.perfMethods in org.apache.storm.perf that return StormTopology Modifier and Type Method Description static StormTopologyKafkaClientSpoutNullBoltTopo. getTopology(Map<String,Object> config)Create and configure the topology.
- 
Uses of StormTopology in org.apache.storm.perf.utilsMethods in org.apache.storm.perf.utils with parameters of type StormTopology Modifier and Type Method Description static voidHelper. runOnClusterAndPrintMetrics(int durationSec, String topoName, Map<String,Object> topoConf, StormTopology topology)
- 
Uses of StormTopology in org.apache.storm.redis.tridentMethods in org.apache.storm.redis.trident that return StormTopology Modifier and Type Method Description static StormTopologyWordCountTridentRedis. buildTopology(String redisHost, Integer redisPort)static StormTopologyWordCountTridentRedisCluster. buildTopology(String redisHostPort)static StormTopologyWordCountTridentRedisClusterMap. buildTopology(String redisHostPort)static StormTopologyWordCountTridentRedisMap. buildTopology(String redisHost, Integer redisPort)
- 
Uses of StormTopology in org.apache.storm.schedulerMethods in org.apache.storm.scheduler that return StormTopology Modifier and Type Method Description StormTopologyTopologyDetails. getTopology()Constructors in org.apache.storm.scheduler with parameters of type StormTopology Constructor Description TopologyDetails(String topologyId, Map<String,Object> topologyConf, StormTopology topology, int numWorkers, String owner)TopologyDetails(String topologyId, Map<String,Object> topologyConf, StormTopology topology, int numWorkers, Map<ExecutorDetails,String> executorToComponents, int launchTime, String owner)TopologyDetails(String topologyId, Map<String,Object> topologyConf, StormTopology topology, int numWorkers, Map<ExecutorDetails,String> executorToComponents, String owner)
- 
Uses of StormTopology in org.apache.storm.scheduler.resourceMethods in org.apache.storm.scheduler.resource with parameters of type StormTopology Modifier and Type Method Description static NormalizedResourceRequestResourceUtils. getBoltResources(StormTopology topology, Map<String,Object> topologyConf, String componentId)static Map<String,NormalizedResourceRequest>ResourceUtils. getBoltsResources(StormTopology topology, Map<String,Object> topologyConf)static NormalizedResourceRequestResourceUtils. getSpoutResources(StormTopology topology, Map<String,Object> topologyConf, String componentId)static Map<String,NormalizedResourceRequest>ResourceUtils. getSpoutsResources(StormTopology topology, Map<String,Object> topologyConf)static voidResourceUtils. updateStormTopologyResources(StormTopology topology, Map<String,Map<String,Double>> resourceUpdatesMap)
- 
Uses of StormTopology in org.apache.storm.serializationConstructors in org.apache.storm.serialization with parameters of type StormTopology Constructor Description IdDictionary(StormTopology topology)
- 
Uses of StormTopology in org.apache.storm.sqlMethods in org.apache.storm.sql that return StormTopology Modifier and Type Method Description abstract StormTopologyAbstractStreamsProcessor. build()Construct the Storm topology based on the SQL.
- 
Uses of StormTopology in org.apache.storm.st.topologyMethods in org.apache.storm.st.topology that return StormTopology Modifier and Type Method Description StormTopologyTestableTopology. newTopology()
- 
Uses of StormTopology in org.apache.storm.st.topology.windowMethods in org.apache.storm.st.topology.window that return StormTopology Modifier and Type Method Description StormTopologySlidingTimeCorrectness. newTopology()StormTopologySlidingWindowCorrectness. newTopology()StormTopologyTumblingTimeCorrectness. newTopology()StormTopologyTumblingWindowCorrectness. newTopology()
- 
Uses of StormTopology in org.apache.storm.starter.tridentMethods in org.apache.storm.starter.trident that return StormTopology Modifier and Type Method Description static StormTopologyTridentMinMaxOfDevicesTopology. buildDevicesTopology()Creates a topology with device-id and count (which are whole numbers) as tuple fields in a stream and it finally generates result stream based on min amd max with device-id and count values.static StormTopologyTridentMapExample. buildTopology()static StormTopologyTridentReach. buildTopology()static StormTopologyTridentWindowingInmemoryStoreTopology. buildTopology(WindowsStoreFactory windowStore, WindowConfig windowConfig)static StormTopologyTridentWordCount. buildTopology()static StormTopologyTridentMinMaxOfDevicesTopology. buildVehiclesTopology()Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with valuesTridentMinMaxOfDevicesTopology.VehicleandTridentMinMaxOfDevicesTopology.Driverrespectively.static StormTopologyTridentMinMaxOfVehiclesTopology. buildVehiclesTopology()Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with valuesTridentMinMaxOfVehiclesTopology.VehicleandTridentMinMaxOfVehiclesTopology.Driverrespectively.
- 
Uses of StormTopology in org.apache.storm.statsMethods in org.apache.storm.stats with parameters of type StormTopology Modifier and Type Method Description static ComponentPageInfoStatsUtil. aggCompExecsStats(Map exec2hostPort, Map task2component, Map<List<Integer>,Map<String,Object>> beats, String window, boolean includeSys, String topologyId, StormTopology topology, String componentId)aggregate component executor stats.static TopologyPageInfoStatsUtil. aggTopoExecsStats(String topologyId, Map exec2nodePort, Map task2component, Map<List<Integer>,Map<String,Object>> beats, StormTopology topology, String window, boolean includeSys, IStormClusterState clusterState)aggregate topo executors stats.static StringStatsUtil. componentType(StormTopology topology, String compId)Get the coponenet type for a give id.static List<Map<String,Object>>StatsUtil. extractDataFromHb(Map executor2hostPort, Map task2component, Map<List<Integer>,Map<String,Object>> beats, boolean includeSys, StormTopology topology)extracts a list of executor data from heart beats.static List<Map<String,Object>>StatsUtil. extractDataFromHb(Map executor2hostPort, Map task2component, Map<List<Integer>,Map<String,Object>> beats, boolean includeSys, StormTopology topology, String compId)extracts a list of executor data from heart beats.
- 
Uses of StormTopology in org.apache.storm.streamsMethods in org.apache.storm.streams that return StormTopology Modifier and Type Method Description StormTopologyStreamBuilder. build()Builds a newStormTopologyfor the computation expressed via the stream api.
- 
Uses of StormTopology in org.apache.storm.taskMethods in org.apache.storm.task that return StormTopology Modifier and Type Method Description StormTopologyGeneralTopologyContext. getRawTopology()Gets the Thrift object representing the topology.Constructors in org.apache.storm.task with parameters of type StormTopology Constructor Description GeneralTopologyContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, String stormId)TopologyContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, Map<String,Long> blobToLastKnownVersionShared, String stormId, String codeDir, String pidDir, Integer taskId, Integer workerPort, List<Integer> workerTasks, Map<String,Object> defaultResources, Map<String,Object> userResources, Map<String,Object> executorData, Map<Integer,Map<Integer,Map<String,IMetric>>> registeredMetrics, AtomicBoolean openOrPrepareWasCalled, StormMetricRegistry metricRegistry)WorkerTopologyContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, String stormId, String codeDir, String pidDir, Integer workerPort, List<Integer> workerTasks, Map<String,Object> defaultResources, Map<String,Object> userResources)WorkerTopologyContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, String stormId, String codeDir, String pidDir, Integer workerPort, List<Integer> workerTasks, Map<String,Object> defaultResources, Map<String,Object> userResources, AtomicReference<Map<Integer,NodeInfo>> taskToNodePort, String assignmentId, AtomicReference<Map<String,String>> nodeToHost)WorkerUserContext(StormTopology topology, Map<String,Object> topoConf, Map<Integer,String> taskToComponent, Map<String,List<Integer>> componentToSortedTasks, Map<String,Map<String,Fields>> componentToStreamToFields, String stormId, String codeDir, String pidDir, Integer workerPort, List<Integer> workerTasks, Map<String,Object> defaultResources, Map<String,Object> userResources, AtomicReference<Map<Integer,NodeInfo>> taskToNodePort, String assignmentId, AtomicReference<Map<String,String>> nodeToHost)
- 
Uses of StormTopology in org.apache.storm.testingMethods in org.apache.storm.testing that return StormTopology Modifier and Type Method Description StormTopologyTrackedTopology. getTopology()Constructors in org.apache.storm.testing with parameters of type StormTopology Constructor Description TrackedTopology(StormTopology origTopo, ILocalCluster cluster)Create a new topology to be tracked.
- 
Uses of StormTopology in org.apache.storm.topologyMethods in org.apache.storm.topology that return StormTopology Modifier and Type Method Description StormTopologyTopologyBuilder. createTopology()
- 
Uses of StormTopology in org.apache.storm.tridentMethods in org.apache.storm.trident that return StormTopology Modifier and Type Method Description StormTopologyTridentTopology. build()
- 
Uses of StormTopology in org.apache.storm.trident.topologyMethods in org.apache.storm.trident.topology that return StormTopology Modifier and Type Method Description StormTopologyTridentTopologyBuilder. buildTopology(Map<String,Number> masterCoordResources)
- 
Uses of StormTopology in org.apache.storm.utilsMethods in org.apache.storm.utils that return StormTopology Modifier and Type Method Description static StormTopologyUtils. addVersions(StormTopology topology)Add version information to the given topology.static StormTopologyConfigUtils. readSupervisorStormCodeGivenPath(String stormCodePath, AdvancedFSOps ops)static StormTopologyConfigUtils. readSupervisorTopology(Map<String,Object> conf, String stormId, AdvancedFSOps ops)StormTopologyConfigUtils. readSupervisorTopologyImpl(Map<String,Object> conf, String stormId, AdvancedFSOps ops)Methods in org.apache.storm.utils with parameters of type StormTopology Modifier and Type Method Description static StormTopologyUtils. addVersions(StormTopology topology)Add version information to the given topology.static List<List<String>>Utils. findComponentCycles(StormTopology topology, String topoId)Find and return components cycles in the topology graph when starting from spout.static ComponentCommonThriftTopologyUtils. getComponentCommon(StormTopology topology, String componentId)static ComponentCommonUtils. getComponentCommon(StormTopology topology, String id)static Set<String>ThriftTopologyUtils. getComponentIds(StormTopology topology)static Map<String,Integer>ServerUtils. getComponentParallelism(Map<String,Object> topoConf, StormTopology topology)static doubleServerUtils. getEstimatedTotalHeapMemoryRequiredByTopo(Map<String,Object> topoConf, StormTopology topology)static intServerUtils. getEstimatedWorkerCountForRasTopo(Map<String,Object> topoConf, StormTopology topology)static Map<String,Map<String,Object>>TopologySpoutLag. lag(StormTopology stormTopology, Map<String,Object> topologyConf)static voidUtils. validateCycleFree(StormTopology topology, String name)Validate that the topology is cycle free.static voidServerUtils. 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 voidServerUtils. validateTopologyWorkerMaxHeapSizeConfigs(Map<String,Object> stormConf, StormTopology topology, double defaultWorkerMaxHeapSizeMb)
 
-