Modifier and Type | Method and Description |
---|---|
List<Column> |
CqlMapper.map(ITuple tuple)
Maps the specified input tuple to a list of CQL columns.
|
List<Column> |
CqlMapper.SelectableCqlMapper.map(ITuple tuple)
Maps the specified input tuple to a list of CQL columns.
|
List<Column> |
CqlMapper.DefaultCqlMapper.map(ITuple tuple)
Maps the specified input tuple to a list of CQL columns.
|
abstract com.datastax.driver.core.Statement |
BaseCQLStatementTupleMapper.map(ITuple tuple)
Maps a given tuple to a single CQL statements.
|
List<com.datastax.driver.core.Statement> |
CQLStatementTupleMapper.map(Map conf,
com.datastax.driver.core.Session session,
ITuple tuple)
Maps a given tuple to one or multiple CQL statements.
|
List<com.datastax.driver.core.Statement> |
CQLStatementTupleMapper.DynamicCQLStatementTupleMapper.map(Map conf,
com.datastax.driver.core.Session session,
ITuple tuple) |
List<com.datastax.driver.core.Statement> |
BaseCQLStatementTupleMapper.map(Map conf,
com.datastax.driver.core.Session session,
ITuple tuple)
Maps a given tuple to one or multiple CQL statements.
|
List<List<Values>> |
CQLResultSetValuesMapper.map(com.datastax.driver.core.Session session,
com.datastax.driver.core.Statement statement,
ITuple tuple) |
String |
ContextQuery.resolves(Map config,
ITuple tuple)
Resolves a cassandra bound query.
|
String |
ContextQuery.StaticContextQuery.resolves(Map config,
ITuple tuple) |
String |
ContextQuery.BoundQueryContext.resolves(Map config,
ITuple tuple) |
String |
ContextQuery.BoundQueryNamedByFieldContext.resolves(Map config,
ITuple tuple) |
Modifier and Type | Method and Description |
---|---|
List<ByteBuffer> |
RoutingKeyGenerator.getRoutingKeys(ITuple tuple) |
List<com.datastax.driver.core.Statement> |
SimpleCQLStatementMapper.map(Map conf,
com.datastax.driver.core.Session session,
ITuple tuple)
Maps a given tuple to one or multiple CQL statements.
|
List<com.datastax.driver.core.Statement> |
BoundCQLStatementTupleMapper.map(Map config,
com.datastax.driver.core.Session session,
ITuple tuple)
Maps a given tuple to one or multiple CQL statements.
|
List<com.datastax.driver.core.Statement> |
BatchCQLStatementTupleMapper.map(Map conf,
com.datastax.driver.core.Session session,
ITuple tuple)
Maps a given tuple to one or multiple CQL statements.
|
Modifier and Type | Method and Description |
---|---|
protected Object |
FieldSelector.getFieldValue(ITuple tuple) |
Column |
FieldSelector.select(ITuple t) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
TridentResultSetValuesMapper.map(com.datastax.driver.core.Session session,
com.datastax.driver.core.Statement statement,
ITuple tuple) |
Modifier and Type | Method and Description |
---|---|
E |
TupleDruidEventMapper.getEvent(ITuple tuple)
Deprecated.
|
E |
ITupleDruidEventMapper.getEvent(ITuple tuple)
Deprecated.
Returns a Druid Event for a given
tuple . |
Modifier and Type | Method and Description |
---|---|
String |
EsTupleMapper.getId(ITuple tuple)
Extracts id from tuple.
|
String |
DefaultEsTupleMapper.getId(ITuple tuple) |
String |
EsTupleMapper.getIndex(ITuple tuple)
Extracts index from tuple.
|
String |
DefaultEsTupleMapper.getIndex(ITuple tuple) |
Map<String,String> |
EsTupleMapper.getParams(ITuple tuple,
Map<String,String> defaultValue)
Extracts params from tuple if available.
|
Map<String,String> |
DefaultEsTupleMapper.getParams(ITuple tuple,
Map<String,String> defaultValue) |
String |
EsTupleMapper.getSource(ITuple tuple)
Extracts source from tuple.
|
String |
DefaultEsTupleMapper.getSource(ITuple tuple) |
String |
EsTupleMapper.getType(ITuple tuple)
Extracts type from tuple.
|
String |
DefaultEsTupleMapper.getType(ITuple tuple) |
Modifier and Type | Method and Description |
---|---|
List<Values> |
HBaseValueMapper.toValues(ITuple input,
org.apache.hadoop.hbase.client.Result result) |
Modifier and Type | Method and Description |
---|---|
List<Values> |
WordCountValueMapper.toValues(ITuple tuple,
org.apache.hadoop.hbase.client.Result result) |
Modifier and Type | Method and Description |
---|---|
List<Column> |
SimpleJdbcMapper.getColumns(ITuple tuple) |
List<Column> |
JdbcMapper.getColumns(ITuple tuple) |
List<Values> |
SimpleJdbcLookupMapper.toTuple(ITuple input,
List<Column> columns) |
List<Values> |
JdbcLookupMapper.toTuple(ITuple input,
List<Column> columns)
Converts a DB row to a list of storm values that can be emitted.
|
Modifier and Type | Method and Description |
---|---|
javax.jms.Message |
JmsMessageProducer.toMessage(javax.jms.Session session,
ITuple input)
Translate a
org.apache.storm.tuple.Tuple object to a javax.jms.Message</code object. |
Modifier and Type | Method and Description |
---|---|
org.bson.conversions.Bson |
SimpleQueryFilterCreator.createFilter(ITuple tuple) |
org.bson.conversions.Bson |
QueryFilterCreator.createFilter(ITuple tuple)
Create a query Filter by given Tuple
|
Modifier and Type | Method and Description |
---|---|
org.bson.Document |
SimpleMongoUpdateMapper.toDocument(ITuple tuple) |
org.bson.Document |
SimpleMongoMapper.toDocument(ITuple tuple) |
org.bson.Document |
MongoMapper.toDocument(ITuple tuple)
Converts a Tuple to a Document
|
Modifier and Type | Method and Description |
---|---|
MqttMessage |
MqttTupleMapper.toMessage(ITuple tuple)
Converts a Tuple to a MqttMessage
|
Modifier and Type | Method and Description |
---|---|
OpenTsdbMetricDatapoint |
TupleOpenTsdbDatapointMapper.getMetricPoint(ITuple tuple) |
OpenTsdbMetricDatapoint |
ITupleOpenTsdbDatapointMapper.getMetricPoint(ITuple tuple)
Returns a
OpenTsdbMetricDatapoint for a given tuple . |
Modifier and Type | Method and Description |
---|---|
String |
TupleMapper.getKeyFromTuple(ITuple tuple)
Extracts key from tuple.
|
String |
TupleMapper.getValueFromTuple(ITuple tuple)
Extracts value from tuple.
|
List<Values> |
RedisLookupMapper.toTuple(ITuple input,
Object value)
Converts return value from Redis to a list of storm values that can be emitted.
|
Modifier and Type | Method and Description |
---|---|
String |
WordCountStoreMapper.getKeyFromTuple(ITuple tuple) |
String |
WordCountLookupMapper.getKeyFromTuple(ITuple tuple) |
String |
WordCountStoreMapper.getValueFromTuple(ITuple tuple) |
String |
WordCountLookupMapper.getValueFromTuple(ITuple tuple) |
List<Values> |
WordCountLookupMapper.toTuple(ITuple input,
Object value) |
Modifier and Type | Method and Description |
---|---|
org.apache.solr.client.solrj.SolrRequest |
SolrMapper.toSolrRequest(ITuple tuple) |
org.apache.solr.client.solrj.SolrRequest |
SolrJsonMapper.toSolrRequest(ITuple tuple) |
org.apache.solr.client.solrj.SolrRequest |
SolrFieldsMapper.toSolrRequest(ITuple tuple) |
Modifier and Type | Method and Description |
---|---|
org.apache.solr.client.solrj.SolrRequest |
SolrMapper.toSolrRequest(List<? extends ITuple> tuples) |
org.apache.solr.client.solrj.SolrRequest |
SolrJsonMapper.toSolrRequest(List<? extends ITuple> tuples) |
org.apache.solr.client.solrj.SolrRequest |
SolrFieldsMapper.toSolrRequest(List<? extends ITuple> tuples) |
Modifier and Type | Interface and Description |
---|---|
interface |
TridentTuple |
Modifier and Type | Class and Description |
---|---|
class |
TridentTupleView
Extends AbstractList so that it can be emitted directly as Storm tuples
|
Modifier and Type | Interface and Description |
---|---|
interface |
Tuple
The tuple is the main data structure in Storm.
|
Modifier and Type | Class and Description |
---|---|
class |
TupleImpl |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.