Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
CQLResultSetValuesMapper.map(com.datastax.driver.core.Session session,
com.datastax.driver.core.Statement statement,
ITuple tuple) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
CassandraQuery.batchRetrieve(CassandraState state,
List<TridentTuple> tridentTuples) |
List<List<Values>> |
CassandraState.batchRetrieve(List<TridentTuple> tridentTuples) |
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 |
---|---|
void |
CassandraQuery.execute(TridentTuple tuple,
List<Values> valuesList,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
Collection<Values> |
EsLookupResultOutput.toValues(org.elasticsearch.client.Response response) |
Collection<Values> |
DefaultEsLookupResultOutput.toValues(org.elasticsearch.client.Response response) |
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<List<Values>> |
HBaseQuery.batchRetrieve(HBaseState hBaseState,
List<TridentTuple> tridentTuples) |
List<List<Values>> |
HBaseState.batchRetrieve(List<TridentTuple> tridentTuples) |
Modifier and Type | Method and Description |
---|---|
void |
HBaseQuery.execute(TridentTuple tuples,
List<Values> values,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
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 | Field and Description |
---|---|
static List<Values> |
UserSpout.rows |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
JdbcQuery.batchRetrieve(JdbcState jdbcState,
List<TridentTuple> tridentTuples) |
List<List<Values>> |
JdbcState.batchRetrieve(List<TridentTuple> tridentTuples) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcQuery.execute(TridentTuple tuples,
List<Values> values,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
Values |
JmsTupleProducer.toTuple(javax.jms.Message msg)
Process a JMS message object to create a Values object.
|
Modifier and Type | Method and Description |
---|---|
Values |
JsonTupleProducer.toTuple(javax.jms.Message msg) |
Modifier and Type | Class and Description |
---|---|
class |
KafkaTuple
A list of Values in a tuple that can be routed to a given stream.
|
Modifier and Type | Method and Description |
---|---|
Values |
MqttMessageMapper.toValues(MqttMessage message)
Convert a
MqttMessage to a set of Values that can be emitted as a Storm Tuple. |
Modifier and Type | Method and Description |
---|---|
Values |
CustomMessageMapper.toValues(MqttMessage message) |
Modifier and Type | Method and Description |
---|---|
Values |
StringMessageMapper.toValues(MqttMessage message) |
Values |
ByteArrayMessageMapper.toValues(MqttMessage message) |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
List<Values> |
WordCountLookupMapper.toTuple(ITuple input,
Object value) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
AbstractRedisStateQuerier.batchRetrieve(T state,
List<TridentTuple> inputs) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRedisStateQuerier.execute(TridentTuple tuple,
List<Values> values,
TridentCollector collector) |
Modifier and Type | Field and Description |
---|---|
static List<Values> |
SolrFieldsSpout.listValues |
Modifier and Type | Method and Description |
---|---|
static Long |
BuiltinAggregateFunctions.Count.add(Long accumulator,
Values vals) |
Modifier and Type | Method and Description |
---|---|
void |
ChannelHandler.dataReceived(ChannelContext ctx,
Values data) |
abstract void |
AbstractChannelHandler.dataReceived(ChannelContext ctx,
Values data) |
void |
ChannelContext.emit(Values data)
Emit data to the next stage of the data pipeline.
|
Modifier and Type | Method and Description |
---|---|
Values |
EvaluationFunction.execute(TridentTuple input) |
Modifier and Type | Method and Description |
---|---|
Iterable<Values> |
EvaluationCalc.execute(TridentTuple input) |
Modifier and Type | Method and Description |
---|---|
void |
MockedSources.addMockData(String spoutId,
String streamId,
Values... valueses)
add mock data for the spout.
|
void |
MockedSources.addMockData(String spoutId,
Values... valueses) |
Modifier and Type | Method and Description |
---|---|
Values |
MapFunction.execute(TridentTuple input)
Invoked by the framework for each trident tuple in a stream.
|
Modifier and Type | Method and Description |
---|---|
Iterable<Values> |
FlatMapFunction.execute(TridentTuple input)
Invoked by the framework for each trident tuple in a stream.
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.