Modifier and Type | Class and Description |
---|---|
class |
LocalCluster.LocalTopology
When running a topology locally, for tests etc.
|
Modifier and Type | Method and 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 |
LocalCluster.getTopology(String id) |
StormTopology |
ILocalCluster.getTopology(String id)
Get the compiled storm topology.
|
StormTopology |
LocalCluster.getUserTopology(String id) |
Modifier and Type | Method and Description |
---|---|
static Testing.CapturedTopology<StormTopology> |
Testing.captureTopology(StormTopology topology)
Rewrites a topology so that all the tuples flowing through it are captured
|
Modifier and Type | Method and 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.
use
TrackedTopology directly. |
void |
ISubmitterHook.notify(TopologyInfo topologyInfo,
Map<String,Object> topoConf,
StormTopology topology) |
LocalCluster.LocalTopology |
LocalCluster.submitTopology(String topologyName,
Map<String,Object> conf,
StormTopology topology) |
ILocalCluster.ILocalTopology |
ILocalCluster.submitTopology(String topologyName,
Map<String,Object> conf,
StormTopology topology)
Submit a topology to be run in local mode.
|
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.
|
LocalCluster.LocalTopology |
LocalCluster.submitTopologyWithOpts(String topologyName,
Map<String,Object> conf,
StormTopology topology,
SubmitOptions submitOpts) |
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) |
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.
|
Constructor and Description |
---|
LocalTopology(String topoName,
StormTopology topo) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
StormCommon.systemTopology(Map<String,Object> topoConf,
StormTopology topology) |
protected StormTopology |
StormCommon.systemTopologyImpl(Map<String,Object> topoConf,
StormTopology topology) |
Modifier and Type | Method and Description |
---|---|
StormTopology |
Nimbus.getTopology(String id) |
StormTopology |
Nimbus.getUserTopology(String id) |
StormTopology |
TopoCache.readTopology(String topoId,
Subject who)
Read a topology.
|
Modifier and Type | Method and 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 .
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
StormTopology |
WorkerState.getSystemTopology() |
StormTopology |
WorkerState.getTopology() |
Modifier and Type | Method and Description |
---|---|
StormTopology |
LinearDRPCTopologyBuilder.createLocalTopology(ILocalDRPC drpc) |
StormTopology |
LinearDRPCTopologyBuilder.createRemoteTopology() |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
FluxBuilder.buildTopology(ExecutionContext context)
Given a topology definition, return a Storm topology that can be run either locally or remotely.
|
Modifier and Type | Method and Description |
---|---|
StormTopology |
TopologySource.getTopology(Map<String,Object> config) |
Modifier and Type | Method and 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.Iface.getTopology(String id)
Returns the compiled topology that contains ackers and metrics consumsers.
|
StormTopology |
Nimbus.Client.getTopology(String id) |
StormTopology |
Nimbus.Iface.getUserTopology(String id)
Returns the user specified topology as submitted originally.
|
StormTopology |
Nimbus.Client.getUserTopology(String id) |
StormTopology |
Nimbus.Client.recv_getTopology() |
StormTopology |
Nimbus.Client.recv_getUserTopology() |
Modifier and Type | Method and 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) |
Modifier and Type | Method and 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.Iface.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology) |
void |
Nimbus.Client.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology) |
void |
Nimbus.AsyncIface.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler) |
void |
Nimbus.AsyncClient.submitTopology(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler) |
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.AsyncIface.submitTopologyWithOpts(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
SubmitOptions options,
org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler) |
void |
Nimbus.AsyncClient.submitTopologyWithOpts(String name,
String uploadedJarLocation,
String jsonConf,
StormTopology topology,
SubmitOptions options,
org.apache.storm.thrift.async.AsyncMethodCallback<Void> resultHandler) |
Modifier and Type | Method and Description |
---|---|
void |
Nimbus.AsyncIface.getTopology(String id,
org.apache.storm.thrift.async.AsyncMethodCallback<StormTopology> resultHandler) |
void |
Nimbus.AsyncClient.getTopology(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.AsyncClient.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) |
Constructor and 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 and 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) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
WordCountTrident.buildTopology(String hbaseRoot) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
TridentFileTopology.buildTopology(String hdfsUrl) |
static StormTopology |
TridentSequenceTopology.buildTopology(String hdfsUrl) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
TridentHiveTopology.buildTopology(String metaStoreUri,
String dbName,
String tblName,
Object keytab,
Object principal) |
Modifier and Type | Method and Description |
---|---|
StormTopology |
UserPersistenceTopology.getTopology() |
StormTopology |
UserPersistenceTridentTopology.getTopology() |
abstract StormTopology |
AbstractUserTopology.getTopology() |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
KafkaProducerTopology.newTopology(String brokerUrl,
String topicName)
Create a new topology that writes random UUIDs to Kafka.
|
Modifier and Type | Method and Description |
---|---|
protected StormTopology |
KafkaSpoutTopologyMainNamedTopics.getTopologyKafkaSpout(KafkaSpoutConfig<String,String> spoutConfig) |
protected StormTopology |
KafkaSpoutTopologyMainWildcardTopics.getTopologyKafkaSpout(KafkaSpoutConfig<String,String> spoutConfig) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
TridentKafkaConsumerTopology.newTopology(ITridentDataSource tridentSpout)
Creates a new topology that prints inputs to stdout.
|
Modifier and Type | Method and Description |
---|---|
static StormTopology |
WordCountTrident.buildTopology(String url,
String collectionName) |
static StormTopology |
WordCountTridentMap.buildTopology(String url,
String collectionName) |
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 | Method and Description |
---|---|
static StormTopology |
KafkaClientSpoutNullBoltTopo.getTopology(Map<String,Object> config)
Create and configure the topology.
|
Modifier and Type | Method and Description |
---|---|
static void |
Helper.runOnClusterAndPrintMetrics(int durationSec,
String topoName,
Map<String,Object> topoConf,
StormTopology topology) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
WordCountTridentRedisClusterMap.buildTopology(String redisHostPort) |
static StormTopology |
WordCountTridentRedisCluster.buildTopology(String redisHostPort) |
static StormTopology |
WordCountTridentRedisMap.buildTopology(String redisHost,
Integer redisPort) |
static StormTopology |
WordCountTridentRedis.buildTopology(String redisHost,
Integer redisPort) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
WordCountTopology.buildTopology(String nameserverAddr,
String topic) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
WordCountTrident.buildTopology(String nameserverAddr,
String topic) |
Modifier and Type | Method and Description |
---|---|
StormTopology |
TopologyDetails.getTopology() |
Constructor and Description |
---|
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) |
TopologyDetails(String topologyId,
Map<String,Object> topologyConf,
StormTopology topology,
int numWorkers,
String owner) |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
IdDictionary(StormTopology topology) |
Modifier and Type | Method and Description |
---|---|
protected StormTopology |
SolrJsonTopology.getTopology() |
protected StormTopology |
SolrFieldsTopology.getTopology() |
protected abstract StormTopology |
SolrTopology.getTopology() |
Modifier and Type | Method and Description |
---|---|
protected void |
SolrTopology.submitTopologyRemoteCluster(String arg,
StormTopology topology,
Config config) |
Modifier and Type | Method and Description |
---|---|
protected StormTopology |
SolrJsonTridentTopology.getTopology() |
protected StormTopology |
SolrFieldsTridentTopology.getTopology() |
Modifier and Type | Method and Description |
---|---|
abstract StormTopology |
AbstractStreamsProcessor.build()
Construct the Storm topology based on the SQL.
|
Modifier and Type | Method and Description |
---|---|
StormTopology |
TestableTopology.newTopology() |
Modifier and Type | Method and Description |
---|---|
StormTopology |
TumblingWindowCorrectness.newTopology() |
StormTopology |
SlidingTimeCorrectness.newTopology() |
StormTopology |
TumblingTimeCorrectness.newTopology() |
StormTopology |
SlidingWindowCorrectness.newTopology() |
Modifier and Type | Method and 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 |
TridentWordCount.buildTopology() |
static StormTopology |
TridentMapExample.buildTopology() |
static StormTopology |
TridentReach.buildTopology() |
static StormTopology |
TridentHBaseWindowingStoreTopology.buildTopology(WindowsStoreFactory windowsStore) |
static StormTopology |
TridentWindowingInmemoryStoreTopology.buildTopology(WindowsStoreFactory windowStore,
WindowConfig windowConfig) |
static StormTopology |
TridentMinMaxOfDevicesTopology.buildVehiclesTopology()
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with values
TridentMinMaxOfDevicesTopology.Vehicle and TridentMinMaxOfDevicesTopology.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 values
TridentMinMaxOfVehiclesTopology.Vehicle and TridentMinMaxOfVehiclesTopology.Driver respectively. |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
StormTopology |
StreamBuilder.build()
Builds a new
StormTopology for the computation expressed via the stream api. |
Modifier and Type | Method and Description |
---|---|
StormTopology |
GeneralTopologyContext.getRawTopology()
Gets the Thrift object representing the topology.
|
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
StormTopology |
TrackedTopology.getTopology() |
Constructor and Description |
---|
TrackedTopology(StormTopology origTopo,
ILocalCluster cluster)
Create a new topology to be tracked.
|
Modifier and Type | Method and Description |
---|---|
StormTopology |
TopologyBuilder.createTopology() |
Modifier and Type | Method and Description |
---|---|
StormTopology |
TridentTopology.build() |
Modifier and Type | Method and Description |
---|---|
StormTopology |
TridentTopologyBuilder.buildTopology(Map<String,Number> masterCoordResources) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
static StormTopology |
Utils.addVersions(StormTopology topology)
Add version information to the given topology.
|
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) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.