Uses of Class
org.apache.storm.tuple.Values
-
-
Uses of Values in org.apache.storm.jdbc.mapper
Methods in org.apache.storm.jdbc.mapper that return types with arguments of type Values Modifier and Type Method Description List<Values>
JdbcLookupMapper. toTuple(ITuple input, List<Column> columns)
Converts a DB row to a list of storm values that can be emitted.List<Values>
SimpleJdbcLookupMapper. toTuple(ITuple input, List<Column> columns)
-
Uses of Values in org.apache.storm.jdbc.spout
Fields in org.apache.storm.jdbc.spout with type parameters of type Values Modifier and Type Field Description static List<Values>
UserSpout. rows
-
Uses of Values in org.apache.storm.jdbc.trident.state
Methods in org.apache.storm.jdbc.trident.state that return types with arguments of type Values Modifier and Type Method Description List<List<Values>>
JdbcQuery. batchRetrieve(JdbcState jdbcState, List<TridentTuple> tridentTuples)
List<List<Values>>
JdbcState. batchRetrieve(List<TridentTuple> tridentTuples)
Method parameters in org.apache.storm.jdbc.trident.state with type arguments of type Values Modifier and Type Method Description void
JdbcQuery. execute(TridentTuple tuples, List<Values> values, TridentCollector tridentCollector)
-
Uses of Values in org.apache.storm.jms
Methods in org.apache.storm.jms that return Values Modifier and Type Method Description Values
JmsTupleProducer. toTuple(javax.jms.Message msg)
Process a JMS message object to create a Values object. -
Uses of Values in org.apache.storm.jms.example
Methods in org.apache.storm.jms.example that return Values Modifier and Type Method Description Values
JsonTupleProducer. toTuple(javax.jms.Message msg)
-
Uses of Values in org.apache.storm.kafka.spout
Subclasses of Values in org.apache.storm.kafka.spout Modifier and Type Class Description class
KafkaTuple
A list of Values in a tuple that can be routed to a given stream:RecordTranslator.apply(org.apache.kafka.clients.consumer.ConsumerRecord<K, V>)
. -
Uses of Values in org.apache.storm.loadgen
Methods in org.apache.storm.loadgen that return Values Modifier and Type Method Description protected Values
LoadSpout. getNextValues(OutputStreamEngine se)
protected Values
ThroughputVsLatency.FastRandomSentenceSpout. getNextValues(OutputStreamEngine se)
-
Uses of Values in org.apache.storm.redis.common.mapper
Methods in org.apache.storm.redis.common.mapper that return types with arguments of type Values Modifier and Type Method Description List<Values>
RedisLookupMapper. toTuple(ITuple input, Object value)
Converts return value from Redis to a list of storm values that can be emitted. -
Uses of Values in org.apache.storm.redis.trident
Methods in org.apache.storm.redis.trident that return types with arguments of type Values Modifier and Type Method Description List<Values>
WordCountLookupMapper. toTuple(ITuple input, Object value)
-
Uses of Values in org.apache.storm.redis.trident.state
Methods in org.apache.storm.redis.trident.state that return types with arguments of type Values Modifier and Type Method Description List<List<Values>>
AbstractRedisStateQuerier. batchRetrieve(T state, List<TridentTuple> inputs)
Method parameters in org.apache.storm.redis.trident.state with type arguments of type Values Modifier and Type Method Description void
AbstractRedisStateQuerier. execute(TridentTuple tuple, List<Values> values, TridentCollector collector)
-
Uses of Values in org.apache.storm.sql
Fields in org.apache.storm.sql with type parameters of type Values Modifier and Type Field Description protected Stream<Values>
AbstractStreamsProcessor. outputStream
Methods in org.apache.storm.sql that return types with arguments of type Values Modifier and Type Method Description Stream<Values>
AbstractStreamsProcessor. outputStream()
Return final output stream of SQL topology structure. -
Uses of Values in org.apache.storm.sql.planner.streams
Methods in org.apache.storm.sql.planner.streams that return types with arguments of type Values Modifier and Type Method Description Stream<Values>
StreamsPlanCreator. pop()
Method parameters in org.apache.storm.sql.planner.streams with type arguments of type Values Modifier and Type Method Description void
StreamsPlanCreator. addStream(Stream<Values> stream)
-
Uses of Values in org.apache.storm.sql.runtime.streams.functions
Methods in org.apache.storm.sql.runtime.streams.functions that return Values Modifier and Type Method Description Values
EvaluationFunction. apply(Values input)
Values
StreamsScanTupleValueMapper. apply(Tuple input)
Methods in org.apache.storm.sql.runtime.streams.functions that return types with arguments of type Values Modifier and Type Method Description Iterable<Values>
EvaluationCalc. apply(Values input)
Pair<Object,Values>
StreamInsertMapToPairFunction. apply(Values input)
Methods in org.apache.storm.sql.runtime.streams.functions with parameters of type Values Modifier and Type Method Description Iterable<Values>
EvaluationCalc. apply(Values input)
Values
EvaluationFunction. apply(Values input)
Pair<Object,Values>
StreamInsertMapToPairFunction. apply(Values input)
boolean
EvaluationFilter. test(Values input)
-
Uses of Values in org.apache.storm.st.topology.window.data
Methods in org.apache.storm.st.topology.window.data that return Values Modifier and Type Method Description Values
TimeData. getValues()
-
Uses of Values in org.apache.storm.streams.operations.mappers
Methods in org.apache.storm.streams.operations.mappers that return Values Modifier and Type Method Description Values
ValuesMapper. apply(Tuple input)
-
Uses of Values in org.apache.storm.testing
Methods in org.apache.storm.testing with parameters of type Values Modifier and Type Method Description void
MockedSources. addMockData(String spoutId, String streamId, Values... valueses)
add mock data for the spout.void
MockedSources. addMockData(String spoutId, Values... valueses)
-
Uses of Values in org.apache.storm.trident.operation
Methods in org.apache.storm.trident.operation that return Values Modifier and Type Method Description Values
MapFunction. execute(TridentTuple input)
Invoked by the framework for each trident tuple in a stream.Methods in org.apache.storm.trident.operation that return types with arguments of type Values Modifier and Type Method Description Iterable<Values>
FlatMapFunction. execute(TridentTuple input)
Invoked by the framework for each trident tuple in a stream.
-