Package | Description |
---|---|
org.apache.storm.cassandra | |
org.apache.storm.cassandra.client | |
org.apache.storm.cassandra.context |
Modifier and Type | Class and Description |
---|---|
static class |
CassandraContext.CassandraConfFactory
Simple class to make
CassandraConf from a Storm topology configuration. |
static class |
CassandraContext.ClientFactory
Simple class to make
CassandraContext.ClientFactory from a Storm topology configuration. |
Modifier and Type | Class and Description |
---|---|
class |
ClusterFactory
Default interface to build cassandra Cluster from the a Storm Topology configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseBeanFactory<T>
Base BeanProvider implementation.
|
Modifier and Type | Method and Description |
---|---|
protected <T> BeanFactory<T> |
WorkerCtx.getBeanfactory(Class<T> clazz)
Return an instance provider of the specified type.
|
BeanFactory<T> |
BeanFactory.newInstance()
Returns a new copy if this factory.
|
BeanFactory<T> |
BaseBeanFactory.newInstance()
Returns a new copy if this factory.
|
Modifier and Type | Method and Description |
---|---|
<T> void |
WorkerCtx.register(Class<T> clazz,
BeanFactory<T> provider)
Register a bean provider for a specified type.
|
Copyright © 2023 The Apache Software Foundation. All rights reserved.