Uses of Class
org.apache.storm.generated.StormTopology
-
-
Uses of StormTopology in org.apache.storm
Subclasses of StormTopology in org.apache.storm Modifier and Type Class Description class
LocalCluster.LocalTopology
When running a topology locally, for tests etc.Methods in org.apache.storm that return StormTopology Modifier and Type Method Description static StormTopology
Thrift. buildTopology(HashMap<String,Thrift.SpoutDetails> spoutMap, HashMap<String,Thrift.BoltDetails> boltMap, HashMap<String,StateSpoutSpec> stateMap)
static StormTopology
Thrift. buildTopology(Map<String,Thrift.SpoutDetails> spoutMap, Map<String,Thrift.BoltDetails> boltMap)
static StormTopology
ExclamationTopology. getStormTopology()
StormTopology
ILocalCluster. getTopology(String id)
Get the compiled storm topology.StormTopology
LocalCluster. getTopology(String id)
StormTopology
LocalCluster. 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 TrackedTopology
Testing. mkTrackedTopology(ILocalCluster cluster, StormTopology topology)
Deprecated.useTrackedTopology
directly.void
ISubmitterHook. notify(TopologyInfo topologyInfo, Map<String,Object> topoConf, StormTopology topology)
ILocalCluster.ILocalTopology
ILocalCluster. submitTopology(String topologyName, Map<String,Object> conf, StormTopology topology)
Submit a topology to be run in local mode.void
LocalCluster. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)
LocalCluster.LocalTopology
LocalCluster. submitTopology(String topologyName, Map<String,Object> conf, 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.ILocalCluster.ILocalTopology
ILocalCluster. submitTopologyWithOpts(String topologyName, Map<String,Object> conf, StormTopology topology, SubmitOptions submitOpts)
Submit a topology to be run in local mode.void
LocalCluster. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)
LocalCluster.LocalTopology
LocalCluster. submitTopologyWithOpts(String topologyName, Map<String,Object> conf, StormTopology topology, SubmitOptions submitOpts)
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.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.daemon
Methods in org.apache.storm.daemon that return StormTopology Modifier and Type Method Description 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)
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 void
StormCommon. addAcker(Map<String,Object> conf, StormTopology topology)
static void
StormCommon. addEventLogger(Map<String,Object> conf, StormTopology topology)
static void
StormCommon. addMetricComponents(Map<String,Object> conf, StormTopology topology)
static void
StormCommon. addMetricStreams(StormTopology topology)
static void
StormCommon. addSystemComponents(Map<String,Object> conf, StormTopology topology)
static void
StormCommon. 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 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 StormTopology in org.apache.storm.daemon.nimbus
Methods in org.apache.storm.daemon.nimbus that return StormTopology Modifier and Type Method Description StormTopology
Nimbus. getTopology(String id)
StormTopology
Nimbus. getUserTopology(String id)
StormTopology
TopoCache. 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 void
TopoCache. addTopology(String topoId, Subject who, StormTopology topo)
Add a new topology.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
TopoCache. updateTopology(String topoId, Subject who, StormTopology topo)
Update an existing topology . -
Uses of StormTopology in org.apache.storm.daemon.ui
Methods 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.worker
Methods in org.apache.storm.daemon.worker that return StormTopology Modifier and Type Method Description StormTopology
WorkerState. getSystemTopology()
StormTopology
WorkerState. getTopology()
-
Uses of StormTopology in org.apache.storm.drpc
Methods in org.apache.storm.drpc that return StormTopology Modifier and Type Method Description StormTopology
LinearDRPCTopologyBuilder. createLocalTopology(ILocalDRPC drpc)
StormTopology
LinearDRPCTopologyBuilder. createRemoteTopology()
-
Uses of StormTopology in org.apache.storm.flux
Methods in org.apache.storm.flux that return StormTopology Modifier and Type Method Description static StormTopology
FluxBuilder. 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.api
Methods in org.apache.storm.flux.api that return StormTopology Modifier and Type Method Description StormTopology
TopologySource. getTopology(Map<String,Object> config)
-
Uses of StormTopology in org.apache.storm.generated
Methods in org.apache.storm.generated that return StormTopology Modifier and Type Method Description StormTopology
StormTopology. deepCopy()
StormTopology
Nimbus.getTopology_result. get_success()
StormTopology
Nimbus.getUserTopology_result. get_success()
StormTopology
Nimbus.submitTopology_args. get_topology()
StormTopology
Nimbus.submitTopologyWithOpts_args. get_topology()
StormTopology
Nimbus.AsyncClient.getTopology_call. getResult()
StormTopology
Nimbus.AsyncClient.getUserTopology_call. getResult()
StormTopology
Nimbus.Client. getTopology(String id)
StormTopology
Nimbus.Iface. getTopology(String id)
Returns the compiled topology that contains ackers and metrics consumsers.StormTopology
Nimbus.Client. getUserTopology(String id)
StormTopology
Nimbus.Iface. getUserTopology(String id)
Returns the user specified topology as submitted originally.StormTopology
Nimbus.Client. recv_getTopology()
StormTopology
Nimbus.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 int
StormTopology. compareTo(StormTopology other)
boolean
StormTopology. equals(StormTopology that)
void
Nimbus.Client. send_submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)
void
Nimbus.Client. send_submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)
void
Nimbus.getTopology_result. set_success(StormTopology success)
void
Nimbus.getUserTopology_result. set_success(StormTopology success)
void
Nimbus.submitTopology_args. set_topology(StormTopology topology)
void
Nimbus.submitTopologyWithOpts_args. set_topology(StormTopology topology)
void
Nimbus.AsyncClient. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)
void
Nimbus.AsyncIface. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)
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.AsyncClient. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)
void
Nimbus.AsyncIface. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options, org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler)
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)
Method parameters in org.apache.storm.generated with type arguments of type StormTopology Modifier and Type Method Description void
Nimbus.AsyncClient. getTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)
void
Nimbus.AsyncIface. getTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)
void
Nimbus.AsyncClient. getUserTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)
void
Nimbus.AsyncIface. getUserTopology(String id, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)
void
Nimbus.AsyncProcessor.getTopology. start(I iface, Nimbus.getTopology_args args, org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler)
void
Nimbus.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.trident
Methods in org.apache.storm.hdfs.trident that return StormTopology Modifier and Type Method Description static StormTopology
TridentFileTopology. buildTopology(String hdfsUrl)
static StormTopology
TridentSequenceTopology. buildTopology(String hdfsUrl)
-
Uses of StormTopology in org.apache.storm.hive.trident
Methods in org.apache.storm.hive.trident that return StormTopology Modifier and Type Method Description static StormTopology
TridentHiveTopology. buildTopology(String metaStoreUri, String dbName, String tblName, Object keytab, Object principal)
-
Uses of StormTopology in org.apache.storm.jdbc.topology
Methods in org.apache.storm.jdbc.topology that return StormTopology Modifier and Type Method Description abstract StormTopology
AbstractUserTopology. getTopology()
StormTopology
UserPersistenceTopology. getTopology()
StormTopology
UserPersistenceTridentTopology. getTopology()
-
Uses of StormTopology in org.apache.storm.kafka.bolt
Methods in org.apache.storm.kafka.bolt that return StormTopology Modifier and Type Method Description static StormTopology
KafkaProducerTopology. newTopology(String brokerUrl, String topicName)
Create a new topology that writes random UUIDs to Kafka. -
Uses of StormTopology in org.apache.storm.kafka.spout
Methods in org.apache.storm.kafka.spout that return StormTopology Modifier and Type Method Description protected StormTopology
KafkaSpoutTopologyMainNamedTopics. getTopologyKafkaSpout(KafkaSpoutConfig<String,String> spoutConfig)
protected StormTopology
KafkaSpoutTopologyMainWildcardTopics. getTopologyKafkaSpout(KafkaSpoutConfig<String,String> spoutConfig)
-
Uses of StormTopology in org.apache.storm.kafka.trident
Methods in org.apache.storm.kafka.trident that return StormTopology Modifier and Type Method Description static StormTopology
TridentKafkaConsumerTopology. newTopology(ITridentDataSource tridentSpout)
Creates a new topology that prints inputs to stdout. -
Uses of StormTopology in org.apache.storm.nimbus
Methods in org.apache.storm.nimbus with parameters of type StormTopology 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 StormTopology in org.apache.storm.perf
Methods in org.apache.storm.perf that return StormTopology Modifier and Type Method Description static StormTopology
KafkaClientSpoutNullBoltTopo. getTopology(Map<String,Object> config)
Create and configure the topology. -
Uses of StormTopology in org.apache.storm.perf.utils
Methods in org.apache.storm.perf.utils with parameters of type StormTopology Modifier and Type Method Description static void
Helper. runOnClusterAndPrintMetrics(int durationSec, String topoName, Map<String,Object> topoConf, StormTopology topology)
-
Uses of StormTopology in org.apache.storm.redis.trident
Methods in org.apache.storm.redis.trident that return StormTopology Modifier and Type Method Description static StormTopology
WordCountTridentRedis. buildTopology(String redisHost, Integer redisPort)
static StormTopology
WordCountTridentRedisCluster. buildTopology(String redisHostPort)
static StormTopology
WordCountTridentRedisClusterMap. buildTopology(String redisHostPort)
static StormTopology
WordCountTridentRedisMap. buildTopology(String redisHost, Integer redisPort)
-
Uses of StormTopology in org.apache.storm.scheduler
Methods in org.apache.storm.scheduler that return StormTopology Modifier and Type Method Description StormTopology
TopologyDetails. 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.resource
Methods in org.apache.storm.scheduler.resource with parameters of type StormTopology Modifier and Type Method Description static NormalizedResourceRequest
ResourceUtils. getBoltResources(StormTopology topology, Map<String,Object> topologyConf, String componentId)
static Map<String,NormalizedResourceRequest>
ResourceUtils. getBoltsResources(StormTopology topology, Map<String,Object> topologyConf)
static NormalizedResourceRequest
ResourceUtils. getSpoutResources(StormTopology topology, Map<String,Object> topologyConf, String componentId)
static Map<String,NormalizedResourceRequest>
ResourceUtils. getSpoutsResources(StormTopology topology, Map<String,Object> topologyConf)
static void
ResourceUtils. updateStormTopologyResources(StormTopology topology, Map<String,Map<String,Double>> resourceUpdatesMap)
-
Uses of StormTopology in org.apache.storm.serialization
Constructors in org.apache.storm.serialization with parameters of type StormTopology Constructor Description IdDictionary(StormTopology topology)
-
Uses of StormTopology in org.apache.storm.sql
Methods in org.apache.storm.sql that return StormTopology Modifier and Type Method Description abstract StormTopology
AbstractStreamsProcessor. build()
Construct the Storm topology based on the SQL. -
Uses of StormTopology in org.apache.storm.st.topology
Methods in org.apache.storm.st.topology that return StormTopology Modifier and Type Method Description StormTopology
TestableTopology. newTopology()
-
Uses of StormTopology in org.apache.storm.st.topology.window
Methods in org.apache.storm.st.topology.window that return StormTopology Modifier and Type Method Description StormTopology
SlidingTimeCorrectness. newTopology()
StormTopology
SlidingWindowCorrectness. newTopology()
StormTopology
TumblingTimeCorrectness. newTopology()
StormTopology
TumblingWindowCorrectness. newTopology()
-
Uses of StormTopology in org.apache.storm.starter.trident
Methods in org.apache.storm.starter.trident that return StormTopology Modifier and Type Method Description static StormTopology
TridentMinMaxOfDevicesTopology. 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 StormTopology
TridentMapExample. buildTopology()
static StormTopology
TridentReach. buildTopology()
static StormTopology
TridentWindowingInmemoryStoreTopology. buildTopology(WindowsStoreFactory windowStore, WindowConfig windowConfig)
static StormTopology
TridentWordCount. buildTopology()
static StormTopology
TridentMinMaxOfDevicesTopology. buildVehiclesTopology()
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with valuesTridentMinMaxOfDevicesTopology.Vehicle
andTridentMinMaxOfDevicesTopology.Driver
respectively.static StormTopology
TridentMinMaxOfVehiclesTopology. buildVehiclesTopology()
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with valuesTridentMinMaxOfVehiclesTopology.Vehicle
andTridentMinMaxOfVehiclesTopology.Driver
respectively. -
Uses of StormTopology in org.apache.storm.stats
Methods in org.apache.storm.stats with parameters of type StormTopology Modifier and Type Method Description static ComponentPageInfo
StatsUtil. 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 TopologyPageInfo
StatsUtil. 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 String
StatsUtil. 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.streams
Methods in org.apache.storm.streams that return StormTopology Modifier and Type Method Description StormTopology
StreamBuilder. build()
Builds a newStormTopology
for the computation expressed via the stream api. -
Uses of StormTopology in org.apache.storm.task
Methods in org.apache.storm.task that return StormTopology Modifier and Type Method Description StormTopology
GeneralTopologyContext. 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.testing
Methods in org.apache.storm.testing that return StormTopology Modifier and Type Method Description StormTopology
TrackedTopology. 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.topology
Methods in org.apache.storm.topology that return StormTopology Modifier and Type Method Description StormTopology
TopologyBuilder. createTopology()
-
Uses of StormTopology in org.apache.storm.trident
Methods in org.apache.storm.trident that return StormTopology Modifier and Type Method Description StormTopology
TridentTopology. build()
-
Uses of StormTopology in org.apache.storm.trident.topology
Methods in org.apache.storm.trident.topology that return StormTopology Modifier and Type Method Description StormTopology
TridentTopologyBuilder. buildTopology(Map<String,Number> masterCoordResources)
-
Uses of StormTopology in org.apache.storm.utils
Methods in org.apache.storm.utils that return StormTopology Modifier and Type Method Description static StormTopology
Utils. addVersions(StormTopology topology)
Add version information to the given topology.static StormTopology
ConfigUtils. readSupervisorStormCodeGivenPath(String stormCodePath, AdvancedFSOps ops)
static StormTopology
ConfigUtils. readSupervisorTopology(Map<String,Object> conf, String stormId, AdvancedFSOps ops)
StormTopology
ConfigUtils. 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 StormTopology
Utils. 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 ComponentCommon
ThriftTopologyUtils. getComponentCommon(StormTopology topology, String componentId)
static ComponentCommon
Utils. 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 double
ServerUtils. getEstimatedTotalHeapMemoryRequiredByTopo(Map<String,Object> topoConf, StormTopology topology)
static int
ServerUtils. getEstimatedWorkerCountForRasTopo(Map<String,Object> topoConf, StormTopology topology)
static Map<String,Map<String,Object>>
TopologySpoutLag. lag(StormTopology stormTopology, Map<String,Object> topologyConf)
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
ServerUtils. validateTopologyWorkerMaxHeapSizeConfigs(Map<String,Object> stormConf, StormTopology topology, double defaultWorkerMaxHeapSizeMb)
-