Uses of Class
org.apache.storm.tuple.Values
Packages that use Values
Package
Description
- 
Uses of Values in org.apache.storm.elasticsearchMethods in org.apache.storm.elasticsearch that return types with arguments of type Values
- 
Uses of Values in org.apache.storm.jdbc.mapperMethods in org.apache.storm.jdbc.mapper that return types with arguments of type Values
- 
Uses of Values in org.apache.storm.jdbc.spoutFields in org.apache.storm.jdbc.spout with type parameters of type Values
- 
Uses of Values in org.apache.storm.jdbc.trident.stateMethods in org.apache.storm.jdbc.trident.state that return types with arguments of type ValuesModifier and TypeMethodDescriptionJdbcQuery.batchRetrieve(JdbcState jdbcState, List<TridentTuple> tridentTuples) JdbcState.batchRetrieve(List<TridentTuple> tridentTuples) Method parameters in org.apache.storm.jdbc.trident.state with type arguments of type ValuesModifier and TypeMethodDescriptionvoidJdbcQuery.execute(TridentTuple tuples, List<Values> values, TridentCollector tridentCollector) 
- 
Uses of Values in org.apache.storm.jmsMethods in org.apache.storm.jms that return Values
- 
Uses of Values in org.apache.storm.jms.exampleMethods in org.apache.storm.jms.example that return Values
- 
Uses of Values in org.apache.storm.kafka.spoutSubclasses of Values in org.apache.storm.kafka.spoutModifier and TypeClassDescriptionclassA 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.loadgenMethods in org.apache.storm.loadgen that return ValuesModifier and TypeMethodDescriptionprotected ValuesLoadSpout.getNextValues(OutputStreamEngine se) protected ValuesThroughputVsLatency.FastRandomSentenceSpout.getNextValues(OutputStreamEngine se) 
- 
Uses of Values in org.apache.storm.redis.common.mapperMethods in org.apache.storm.redis.common.mapper that return types with arguments of type Values
- 
Uses of Values in org.apache.storm.redis.tridentMethods in org.apache.storm.redis.trident that return types with arguments of type Values
- 
Uses of Values in org.apache.storm.redis.trident.stateMethods in org.apache.storm.redis.trident.state that return types with arguments of type ValuesModifier and TypeMethodDescriptionAbstractRedisStateQuerier.batchRetrieve(T state, List<TridentTuple> inputs) Method parameters in org.apache.storm.redis.trident.state with type arguments of type ValuesModifier and TypeMethodDescriptionvoidAbstractRedisStateQuerier.execute(TridentTuple tuple, List<Values> values, TridentCollector collector) 
- 
Uses of Values in org.apache.storm.sqlFields in org.apache.storm.sql with type parameters of type ValuesMethods in org.apache.storm.sql that return types with arguments of type ValuesModifier and TypeMethodDescriptionAbstractStreamsProcessor.outputStream()Return final output stream of SQL topology structure.
- 
Uses of Values in org.apache.storm.sql.planner.streamsMethods in org.apache.storm.sql.planner.streams that return types with arguments of type ValuesMethod parameters in org.apache.storm.sql.planner.streams with type arguments of type Values
- 
Uses of Values in org.apache.storm.sql.runtime.streams.functionsMethods in org.apache.storm.sql.runtime.streams.functions that return ValuesModifier and TypeMethodDescriptionMethods in org.apache.storm.sql.runtime.streams.functions that return types with arguments of type ValuesModifier and TypeMethodDescriptionMethods in org.apache.storm.sql.runtime.streams.functions with parameters of type Values
- 
Uses of Values in org.apache.storm.st.topology.window.dataMethods in org.apache.storm.st.topology.window.data that return Values
- 
Uses of Values in org.apache.storm.streams.operations.mappersMethods in org.apache.storm.streams.operations.mappers that return Values
- 
Uses of Values in org.apache.storm.testingMethods in org.apache.storm.testing with parameters of type ValuesModifier and TypeMethodDescriptionvoidMockedSources.addMockData(String spoutId, String streamId, Values... valueses) add mock data for the spout.voidMockedSources.addMockData(String spoutId, Values... valueses) 
- 
Uses of Values in org.apache.storm.trident.operationMethods in org.apache.storm.trident.operation that return ValuesModifier and TypeMethodDescriptionMapFunction.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 ValuesModifier and TypeMethodDescriptionFlatMapFunction.execute(TridentTuple input) Invoked by the framework for each trident tuple in a stream.