Uses of Class
org.apache.storm.tuple.Values
Package
Description
-
Uses of Values in org.apache.storm.elasticsearch
-
Uses of Values in org.apache.storm.jdbc.mapper
-
Uses of Values in org.apache.storm.jdbc.spout
-
Uses of Values in org.apache.storm.jdbc.trident.state
Modifier and TypeMethodDescriptionJdbcQuery.batchRetrieve
(JdbcState jdbcState, List<TridentTuple> tridentTuples) JdbcState.batchRetrieve
(List<TridentTuple> tridentTuples) Modifier and TypeMethodDescriptionvoid
JdbcQuery.execute
(TridentTuple tuples, List<Values> values, TridentCollector tridentCollector) -
Uses of Values in org.apache.storm.jms
-
Uses of Values in org.apache.storm.jms.example
-
Uses of Values in org.apache.storm.kafka.spout
Modifier and TypeClassDescriptionclass
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
Modifier and TypeMethodDescriptionprotected Values
LoadSpout.getNextValues
(OutputStreamEngine se) protected Values
ThroughputVsLatency.FastRandomSentenceSpout.getNextValues
(OutputStreamEngine se) -
Uses of Values in org.apache.storm.redis.common.mapper
-
Uses of Values in org.apache.storm.redis.trident
-
Uses of Values in org.apache.storm.redis.trident.state
Modifier and TypeMethodDescriptionAbstractRedisStateQuerier.batchRetrieve
(T state, List<TridentTuple> inputs) Modifier and TypeMethodDescriptionvoid
AbstractRedisStateQuerier.execute
(TridentTuple tuple, List<Values> values, TridentCollector collector) -
Uses of Values in org.apache.storm.sql
Modifier and TypeMethodDescriptionAbstractStreamsProcessor.outputStream()
Return final output stream of SQL topology structure. -
Uses of Values in org.apache.storm.sql.planner.streams
-
Uses of Values in org.apache.storm.sql.runtime.streams.functions
Modifier and TypeMethodDescriptionModifier and TypeMethodDescription -
Uses of Values in org.apache.storm.st.topology.window.data
-
Uses of Values in org.apache.storm.streams.operations.mappers
-
Uses of Values in org.apache.storm.testing
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionMapFunction.execute
(TridentTuple input) Invoked by the framework for each trident tuple in a stream.Modifier and TypeMethodDescriptionFlatMapFunction.execute
(TridentTuple input) Invoked by the framework for each trident tuple in a stream.