Package | Description |
---|---|
org.apache.storm.flux | |
org.apache.storm.flux.model | |
org.apache.storm.hdfs.avro | |
org.apache.storm.kafka.spout | |
org.apache.storm.solr.topology | |
org.apache.storm.topology |
Modifier and Type | Method and Description |
---|---|
static Config |
FluxBuilder.buildConfig(TopologyDef topologyDef)
Given a topology definition, return a populated
org.apache.storm.Config instance. |
Constructor and Description |
---|
ExecutionContext(TopologyDef topologyDef,
Config config) |
Modifier and Type | Method and Description |
---|---|
static void |
AvroUtils.addAvroKryoSerializations(Config conf)
A helper method to extract avro serialization configurations from the topology configuration and register specific kryo serializers as necessary.
|
Modifier and Type | Method and Description |
---|---|
protected Config |
KafkaSpoutTopologyMainNamedTopics.getConfig() |
Modifier and Type | Method and Description |
---|---|
protected Config |
SolrTopology.getConfig() |
Modifier and Type | Method and Description |
---|---|
protected void |
SolrTopology.submitTopologyRemoteCluster(String arg,
StormTopology topology,
Config config) |
Modifier and Type | Field and Description |
---|---|
protected Config |
ConfigurableTopology.conf |
Modifier and Type | Method and Description |
---|---|
protected Config |
ConfigurableTopology.getConf() |
static Config |
ConfigurableTopology.loadConf(String resource,
Config conf) |
Modifier and Type | Method and Description |
---|---|
static Config |
ConfigurableTopology.loadConf(String resource,
Config conf) |
protected int |
ConfigurableTopology.submit(Config conf,
TopologyBuilder builder)
Submits the topology with the name taken from the configuration.
|
protected int |
ConfigurableTopology.submit(String name,
Config conf,
TopologyBuilder builder)
Submits the topology under a specific name.
|
Copyright © 2019 The Apache Software Foundation. All rights reserved.