Index

A B C D E F G H I K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

addNamedSink(String, VoltStreamSinkConfigurator<T>) - Method in interface org.voltdb.stream.api.pipeline.ExceptionHandlerBuilder
 
addNamedSink(String, VoltStreamSink<T>) - Method in interface org.voltdb.stream.api.pipeline.ExceptionHandlerBuilder
 
asInt() - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
asList(Class<T>) - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
asLong() - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
asMap(Class<K>, Class<V>) - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
asString() - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
ASYNC_COMMIT_TIMEOUT_MS_PROPERTY - Static variable in interface org.voltdb.stream.api.VoltEnvironment
 

B

BaseMetric - Enum Class in org.voltdb.stream.execution.metric
 
BaseTag - Enum Class in org.voltdb.stream.execution.metric
 
BatchAccumulator<I,O> - Class in org.voltdb.stream.function
A processing function that accumulates incoming data items into a single aggregated result and emits the result once a batch is processed.
BatchAccumulator(O, BiFunction<O, I, O>) - Constructor for class org.voltdb.stream.function.BatchAccumulator
Constructs a BatchAccumulator with the specified initial accumulator and accumulation function.
batchProcessed(long) - Method in interface org.voltdb.stream.api.extension.StreamFunction
 
batchProcessed(long) - Method in interface org.voltdb.stream.api.extension.StreamSink
 
batchProcessed(long) - Method in interface org.voltdb.stream.api.pipeline.VoltFunction
the callback is invoked when the function finishes processing a batch of data
batchProcessed(long) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamSink
the callback is invoked when the sink finishes processing a batch of data
batchProcessed(long) - Method in class org.voltdb.stream.function.BatchAccumulator
 

C

cancel() - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
 
CancelingFunction<I,O> - Class in org.voltdb.stream.function
This identity function, but it accumulates value with given accumulatorFunction, and cancels the execution once the accumulated value exceeds given threshold.
CancelingFunction(O, O, BiFunction<O, I, O>) - Constructor for class org.voltdb.stream.function.CancelingFunction
Constructs a CancelingFunction with the specified initial accumulator, threshold, and accumulator function.
clear() - Method in class org.voltdb.stream.sink.IterableSink
Clears all data items from the internal sink.
COLLECTED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
COLOR - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
commit(long, ExecutionContext) - Method in interface org.voltdb.stream.api.extension.StreamSink
 
commit(long, ExecutionContext) - Method in interface org.voltdb.stream.api.extension.StreamSource
 
commit(long, ExecutionContext) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamSource
the callback is invoked when the source has to perform any logic assuring data has been successfully processed and upstream system can make progress.
commit(ExecutionContext) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamSink
the callback is invoked when the sink has to perform any logic assuring data is securely passed to downstream system
commit(ExecutionContext) - Method in class org.voltdb.stream.sink.FileSink
 
commit(ExecutionContext) - Method in class org.voltdb.stream.sink.StdoutSink
 
CommitResult - Interface in org.voltdb.stream.api.extension
This interface represents results of potentially asynchronous commit action.
CommitResult.AsynchronousResultHandler - Interface in org.voltdb.stream.api.extension
 
CommitResult.CommitTimeoutException - Exception Class in org.voltdb.stream.api.extension
 
COMMITTED - Static variable in interface org.voltdb.stream.api.extension.CommitResult
 
CommitTimeoutException(String) - Constructor for exception class org.voltdb.stream.api.extension.CommitResult.CommitTimeoutException
 
CompletableCommitResult - Interface in org.voltdb.stream.api.extension
 
complete(long) - Method in interface org.voltdb.stream.api.extension.CompletableCommitResult
 
completeExceptionally(long, List<?>, Throwable) - Method in interface org.voltdb.stream.api.extension.CompletableCommitResult
 
ConfigurableOperatorProducer<C> - Interface in org.voltdb.stream.api.extension
 
Configuration - Interface in org.voltdb.stream.execution
 
CONFIGURATION - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
Configuration.ConfigurationPart - Interface in org.voltdb.stream.execution
Represents configuration part that is obtained from yaml configuration.
configurator() - Method in interface org.voltdb.stream.api.ExecutionContext
Operator configuration helper methods
configure(ExecutionContext) - Method in interface org.voltdb.stream.api.pipeline.VoltLifecycle
 
configure(ExecutionContext) - Method in class org.voltdb.stream.sink.FileSink
 
configure(ExecutionContext) - Method in class org.voltdb.stream.source.GeneratorSource
 
configure(VoltEnvironment) - Method in interface org.voltdb.stream.api.extension.OperatorConfigurator
 
configureOnce(String, Supplier<RESULT>) - Method in interface org.voltdb.stream.api.ExecutionContext.ConfigurationContext
 
configureOnce(String, Supplier<RESULT>) - Method in class org.voltdb.stream.execution.GlobalConfigurationContext
 
CONNECTION_ID - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
consume(Object, ExecutionContext) - Method in interface org.voltdb.stream.api.extension.StreamSink
 
consume(O) - Method in interface org.voltdb.stream.api.Consumer
This method is invoked by any upstream caller, the caller can emmit any number of events to a consumer.
consume(T) - Method in class org.voltdb.stream.sink.FileSink
 
consume(T) - Method in class org.voltdb.stream.sink.IterableSink
 
consume(T) - Method in class org.voltdb.stream.sink.StdoutSink
 
consumeFromSource(VoltStreamSourceConfigurator<T>) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamBuilder
Each stream must have one source.
consumeFromSource(VoltStreamSource<T>) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamBuilder
Each stream must have one source.
Consumer<O> - Interface in org.voltdb.stream.api
A Consumer is a link between upstream and downstream operator.
copy() - Method in class org.voltdb.stream.sink.IterableSink
Creates and returns a copy of the current contents of the sink.
CPU_AVAILABLE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
CPU_LOAD - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
CPU_LOAD_OS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
CPU_LOAD_PROCESS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 

D

DATABASE - Enum constant in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
 
DEFAULT_ASYNC_COMMIT_TIMEOUT - Static variable in interface org.voltdb.stream.api.VoltEnvironment
system consumes batch of data from source and push it to sink, then those operators are committed one by one.
define(VoltStreamBuilder) - Method in interface org.voltdb.stream.api.pipeline.VoltPipeline
 
destroy(ExecutionContext) - Method in interface org.voltdb.stream.api.pipeline.VoltLifecycle
 
destroy(ExecutionContext) - Method in class org.voltdb.stream.source.GeneratorSource
 
DISK_SWAP_SPACE_FREE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
DISK_SWAP_SPACE_TOTAL - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 

E

emit(String, Object) - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
Emits a message into named sink after receiving exception.
EMITTED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
ExceptionHandler - Interface in org.voltdb.stream.api.pipeline
Stream's global exception handler.
ExceptionHandlerBuilder - Interface in org.voltdb.stream.api.pipeline
 
execution() - Method in interface org.voltdb.stream.api.ExecutionContext
 
ExecutionContext - Interface in org.voltdb.stream.api
 
ExecutionContext.ConfigurationContext - Interface in org.voltdb.stream.api
 
ExecutionContext.StreamExecutionContext - Interface in org.voltdb.stream.api
 
extractSafe(String) - Static method in class org.voltdb.stream.execution.Property
 
extractSafe(String, String) - Static method in class org.voltdb.stream.execution.Property
 
extractSafe(String, String, boolean) - Static method in class org.voltdb.stream.execution.Property
 
extractSafeList(String) - Static method in class org.voltdb.stream.execution.Property
 

F

FILE_DESCRIPTORS_LIMIT - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
FILE_DESCRIPTORS_OPEN - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
FileSink<T> - Class in org.voltdb.stream.sink
A sink that writes streamed data items to a file within a specified directory.
FileSink(String) - Constructor for class org.voltdb.stream.sink.FileSink
Constructs a FileSink with the specified directory path.
FileSink(String, String, Function<T, byte[]>) - Constructor for class org.voltdb.stream.sink.FileSink
Constructs a FileSink with the specified directory path, line terminator, and encoder.
fillInStackTrace() - Method in exception class org.voltdb.stream.api.VoltEnvironment.VoltCommitException
 
findByPath(String, String...) - Method in interface org.voltdb.stream.execution.Configuration
This method obtains a value through a name or path to property from a yaml configuration.
findByPath(String, String...) - Method in class org.voltdb.stream.execution.GlobalConfigurationContext
 
from(Collection<T>) - Static method in class org.voltdb.stream.source.IterableSource
Creates a source from the given Collection.
fromException(Throwable) - Static method in interface org.voltdb.stream.api.extension.CommitResult
 
fromId(int) - Static method in enum class org.voltdb.stream.execution.metric.BaseMetric
 
FUNCTION - Enum constant in enum class org.voltdb.stream.api.extension.Operator.Type
 
FUNCTION - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 

G

GC_COUNT - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
GC_TIME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
GC_TYPE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
GENERAL - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
GeneratorSource<T> - Class in org.voltdb.stream.source
Base class for simple sources that generate elements algorithmically.
GeneratorSource() - Constructor for class org.voltdb.stream.source.GeneratorSource
 
getAdditionalSinks() - Method in interface org.voltdb.stream.api.extension.VoltStream
 
getAffectedMessages() - Method in interface org.voltdb.stream.api.extension.CommitResult
 
getCause() - Method in interface org.voltdb.stream.api.extension.CommitResult
 
getColor() - Method in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
 
getConfiguration() - Method in interface org.voltdb.stream.api.extension.OperatorConfigurator
 
getContext() - Static method in class org.voltdb.stream.execution.GlobalConfigurationContext
 
getExceptionHandler() - Method in interface org.voltdb.stream.api.extension.VoltStream
 
getExecutionContext() - Method in interface org.voltdb.stream.api.pipeline.VoltStreamBuilder
 
getIcon() - Method in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
 
getName() - Method in interface org.voltdb.stream.api.extension.VoltStream
 
getPipelineClass() - Method in interface org.voltdb.stream.api.VoltEnvironment
Returns pipeline's class configured for this runtime.
getPipelineName() - Method in interface org.voltdb.stream.api.ExecutionContext
The name of the pipeline.
getSink() - Method in interface org.voltdb.stream.api.extension.VoltStream
 
getSource() - Method in interface org.voltdb.stream.api.extension.VoltStream
 
getSteps() - Method in interface org.voltdb.stream.api.extension.VoltStream
 
getType() - Method in interface org.voltdb.stream.api.extension.Operator
 
getType() - Method in interface org.voltdb.stream.api.extension.StreamFunction
 
getType() - Method in interface org.voltdb.stream.api.extension.StreamSink
 
getType() - Method in interface org.voltdb.stream.api.extension.StreamSource
 
getType() - Method in enum class org.voltdb.stream.execution.metric.BaseMetric
 
getUnit() - Method in enum class org.voltdb.stream.execution.metric.BaseMetric
 
getValue() - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
GlobalConfigurationContext - Class in org.voltdb.stream.execution
 

H

handle(List<?>, ExecutionContext, Throwable) - Method in interface org.voltdb.stream.api.pipeline.ExceptionHandler
Gets affected messages (records) and exception.
handleAsynchronously(CommitResult.AsynchronousResultHandler) - Method in interface org.voltdb.stream.api.extension.CommitResult
 
handleResult(CommitResult) - Method in interface org.voltdb.stream.api.extension.CommitResult.AsynchronousResultHandler
 
hasNext() - Method in class org.voltdb.stream.source.GeneratorSource
A way for the implementation to indicate wheter there are more items to generate in the stream.
hasNext() - Method in class org.voltdb.stream.source.IterableSource
 
hasValue() - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
HOST_NAME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 

I

ICON - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
ID - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
initialize(Consumer<Object>) - Method in interface org.voltdb.stream.api.extension.StreamFunction
 
initialize(Consumer<O>) - Method in interface org.voltdb.stream.api.pipeline.VoltFunction
the callback is invoked when the function is created and a consumer is assigned but the function is not yet scheduled to handle any incoming events.
initialize(Consumer<O>) - Method in class org.voltdb.stream.function.BatchAccumulator
 
isAsync() - Method in interface org.voltdb.stream.api.extension.CommitResult
 
isCanceled() - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
 
isDone() - Method in interface org.voltdb.stream.api.extension.CommitResult
 
IterableSink<T> - Class in org.voltdb.stream.sink
Captures all stream items into a list.
IterableSink() - Constructor for class org.voltdb.stream.sink.IterableSink
 
IterableSource<T> - Class in org.voltdb.stream.source
Generates a stream of data items from an Iterable.
iterate(T...) - Static method in class org.voltdb.stream.source.IterableSource
Creates a source from the provided elements.

K

KAFKA - Enum constant in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
 
KAFKA_BATCH_SIZE_MAX - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_BUFFER_EXHAUSTED_RATE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_BYTES_CONSUMED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_COMMIT_RATE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_COMMIT_SYNC_TIME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_COMMITS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_CONNECTION_CLOSE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_CONNECTION_COUNT - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_FETCH_LATENCY_MAX - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_FETCH_RATE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_FETCH_SIZE_MAX - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_INCOMING - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_IO_TIME_NS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_IO_WAIT_TIME_NS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_LAST_POLL_SECONDS_AGO - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_NETWORK_IO - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_OUTGOING_BYTE_RATE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORD_ERROR_RATE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORD_QUEUE_TIME_AVG - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORD_RETRY - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORD_SEND - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORD_SEND_RATE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORDS_CONSUMED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_RECORDS_PER_REQUEST_AVG - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_REQUEST_IN_FLIGHT - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_REQUEST_SIZE_AVG - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SINK_BYTES_PUSHED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SINK_MESSAGES_CONSUMED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SINK_MESSAGES_PUSHED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SINK_PULL_DELAY - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SINK_PUSH_TIME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SOURCE_BYTES_PULLED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SOURCE_GROUP_ID - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
KAFKA_SOURCE_MESSAGES_PULLED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SOURCE_PARTITION_ASSIGNED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SOURCE_PULL_DELAY - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SOURCE_PULL_ERRORS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_SOURCE_PULL_TIME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_START_TIME_MS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_TIME_BETWEEN_POLL_MAX - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
KAFKA_TOPIC - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
KAFKA_WAITING_THREADS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 

L

lookup(OperatorConfigurator) - Method in interface org.voltdb.stream.api.VoltEnvironment
The framework is looking up possible implementations of registered operators.

M

MEMORY_JAVA_HEAP_MAX - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
MEMORY_JAVA_HEAP_USED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
MEMORY_JAVA_NONHEAP_USED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
MEMORY_SIZE_COMMITTED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
MEMORY_SIZE_FREE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
MEMORY_SIZE_TOTAL - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 

N

NAME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
nanoTime() - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
 
next() - Method in class org.voltdb.stream.source.GeneratorSource
Implementation should generate the next item in the stream.
next() - Method in class org.voltdb.stream.source.IterableSource
 
nextBatchId() - Method in interface org.voltdb.stream.api.ExecutionContext
Method used by the framework, creates unique number that can identify batch of data.
nextBatchStarts(long) - Method in interface org.voltdb.stream.api.extension.StreamFunction
 
nextBatchStarts(long) - Method in interface org.voltdb.stream.api.extension.StreamSink
 
nextBatchStarts(long) - Method in interface org.voltdb.stream.api.pipeline.VoltFunction
the callback is invoked when the function starts processing a new batch of data
nextBatchStarts(long) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamSink
the callback is invoked when the sink starts processing a new batch of data
nextCommitResult() - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
Creates and manages CompletableCommitResult.
nextCommitResult(Duration) - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
Creates and manages CompletableCommitResult.
NODE_GRAPH - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
NODE_GRAPH_EDGES - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
NodeGraphRecorder - Class in org.voltdb.stream.execution.metric
 
NodeGraphRecorder() - Constructor for class org.voltdb.stream.execution.metric.NodeGraphRecorder
 
NodeGraphRecorder.EntityType - Enum Class in org.voltdb.stream.execution.metric
 

O

observer() - Method in interface org.voltdb.stream.api.ExecutionContext
 
onError() - Method in interface org.voltdb.stream.api.pipeline.VoltStreamBuilder
Defines exception handling behaviour of this stream.
Operator - Interface in org.voltdb.stream.api.extension
this is a most basic building block of the stream.
Operator.Type - Enum Class in org.voltdb.stream.api.extension
 
OperatorConfigurator - Interface in org.voltdb.stream.api.extension
 
orElse(T) - Method in interface org.voltdb.stream.execution.Configuration.ConfigurationPart
 
org.voltdb.stream.api - package org.voltdb.stream.api
 
org.voltdb.stream.api.extension - package org.voltdb.stream.api.extension
 
org.voltdb.stream.api.pipeline - package org.voltdb.stream.api.pipeline
 
org.voltdb.stream.execution - package org.voltdb.stream.execution
 
org.voltdb.stream.execution.metric - package org.voltdb.stream.execution.metric
 
org.voltdb.stream.function - package org.voltdb.stream.function
 
org.voltdb.stream.sink - package org.voltdb.stream.sink
 
org.voltdb.stream.source - package org.voltdb.stream.source
 

P

PARTITION_ID - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
PIPELINE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
PIPELINE - Enum constant in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
 
PROCEDURE_NAME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
process(long, Consumer<Object>, ExecutionContext) - Method in interface org.voltdb.stream.api.extension.StreamSource
 
process(long, Consumer<T>, ExecutionContext) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamSource
Whenever a scheduler has an idle worker it will bind a worker to the source allowing the source to starts processing data.
process(long, Consumer<T>, ExecutionContext) - Method in class org.voltdb.stream.source.GeneratorSource
 
process(I, Consumer<I>, ExecutionContext) - Method in class org.voltdb.stream.function.CancelingFunction
 
process(I, Consumer<O>, ExecutionContext) - Method in interface org.voltdb.stream.api.pipeline.VoltFunction
processes input and emits output messages to a consumer
process(I, Consumer<O>, ExecutionContext) - Method in class org.voltdb.stream.function.BatchAccumulator
 
process(Object, Consumer<Object>, ExecutionContext) - Method in interface org.voltdb.stream.api.extension.StreamFunction
 
processWith(Function<I, O>) - Method in interface org.voltdb.stream.api.pipeline.VoltOpenStreamBuilder
 
processWith(VoltFunctionConfigurator<I, O>) - Method in interface org.voltdb.stream.api.pipeline.VoltOpenStreamBuilder
 
processWith(VoltFunction<I, O>) - Method in interface org.voltdb.stream.api.pipeline.VoltOpenStreamBuilder
 
produce(C) - Method in interface org.voltdb.stream.api.extension.ConfigurableOperatorProducer
 
produceOperators(C) - Method in interface org.voltdb.stream.api.extension.ConfigurableOperatorProducer
 
Property - Class in org.voltdb.stream.execution
 

R

RANDOM - Enum constant in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
 
range(int, int) - Static method in class org.voltdb.stream.source.IterableSource
Creates a source that generates a range of integers from start (inclusive) to end (exclusive).
register(Class<C>, ConfigurableOperatorProducer<C>) - Method in interface org.voltdb.stream.api.VoltEnvironment
The framework can be extended with any logic delivered as source, function or sink.
registerExtension(VoltEnvironment) - Method in interface org.voltdb.stream.api.extension.VoltStreamExtension
 
registerNode(Observer, String, NodeGraphRecorder.EntityType) - Static method in class org.voltdb.stream.execution.metric.NodeGraphRecorder
 
registerNodeAndEdge(Observer, String, String, String, NodeGraphRecorder.EntityType) - Static method in class org.voltdb.stream.execution.metric.NodeGraphRecorder
 

S

setExceptionHandler(ExceptionHandler) - Method in interface org.voltdb.stream.api.pipeline.ExceptionHandlerBuilder
 
SINK - Enum constant in enum class org.voltdb.stream.api.extension.Operator.Type
 
SINK - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
SINK_TARGET - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
SOURCE - Enum constant in enum class org.voltdb.stream.api.extension.Operator.Type
 
SOURCE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
sourceTags - Variable in class org.voltdb.stream.source.GeneratorSource
Tags associated with this source, used for metrics.
STAGE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
STAGE_EXECUTION_TIME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
STAGE_FAILURE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
START_TIME - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
StdoutSink<T> - Class in org.voltdb.stream.sink
A sink that writes streamed data items to the standard output (console).
StdoutSink(Function<T, CharSequence>) - Constructor for class org.voltdb.stream.sink.StdoutSink
Constructs a StdoutSink with the specified encoder function.
STREAM_SINK - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
STREAM_SOURCE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
StreamFunction - Interface in org.voltdb.stream.api.extension
 
StreamSink - Interface in org.voltdb.stream.api.extension
 
StreamSource - Interface in org.voltdb.stream.api.extension
this interface is a 1-1 copy of VoltStreamSource but it drops generics.
SUBTITLE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
SYSTEM_PROPERTIES - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 

T

TARGET - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
terminateWithSink(VoltStreamSinkConfigurator<O>) - Method in interface org.voltdb.stream.api.pipeline.VoltOpenStreamBuilder
 
terminateWithSink(VoltStreamSink<O>) - Method in interface org.voltdb.stream.api.pipeline.VoltOpenStreamBuilder
 
threadSafeObserver() - Method in interface org.voltdb.stream.api.ExecutionContext
 
TITLE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
toStringSink() - Static method in class org.voltdb.stream.sink.StdoutSink
Creates a StdoutSink that converts each consumed object to its string representation.
trace(String, Object...) - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
A logging helper method.
traceValue(String, Object) - Method in interface org.voltdb.stream.api.ExecutionContext.StreamExecutionContext
In test environment the named value will be collected so those named values can be later examined.

U

UNKNOWN - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
UNKNOWN - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
Usage Example - Search tag in class org.voltdb.stream.function.BatchAccumulator
Section
Usage Example - Search tag in class org.voltdb.stream.function.CancelingFunction
Section

V

valueOf(String) - Static method in enum class org.voltdb.stream.api.extension.Operator.Type
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.voltdb.stream.execution.metric.BaseMetric
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.voltdb.stream.execution.metric.BaseTag
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.voltdb.stream.api.extension.Operator.Type
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.voltdb.stream.execution.metric.BaseMetric
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.voltdb.stream.execution.metric.BaseTag
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.voltdb.stream.execution.metric.NodeGraphRecorder.EntityType
Returns an array containing the constants of this enum class, in the order they are declared.
VERSION - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
VOLT_AFFINITY_READS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_AFFINITY_WRITES - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_BATCH_SIZE - Enum constant in enum class org.voltdb.stream.execution.metric.BaseTag
 
VOLT_PROCEDURE_BYTES_READ - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_PROCEDURE_BYTES_WRITTEN - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_PROCEDURE_INVOCATION_ABORTS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_PROCEDURE_INVOCATION_COMPLETED - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_PROCEDURE_INVOCATION_ERRORS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_PROCEDURE_INVOCATION_LATENCY - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_PROCEDURE_INVOCATION_TIMEOUTS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_ROUNDROBIN_READS - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_ROUNDROBIN_WRITES - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VOLT_SINK - Enum constant in enum class org.voltdb.stream.execution.metric.BaseMetric
 
VoltCommitException(String) - Constructor for exception class org.voltdb.stream.api.VoltEnvironment.VoltCommitException
 
VoltEnvironment - Interface in org.voltdb.stream.api
Defines execution environment in which stream operates.
VoltEnvironment.VoltCommitException - Exception Class in org.voltdb.stream.api
 
VoltEnvironment.VoltStreamException - Exception Class in org.voltdb.stream.api
 
VoltFunction<I,O> - Interface in org.voltdb.stream.api.pipeline
This class represents a simple transformation between input event and output message.
VoltFunctionConfigurator<I,O> - Interface in org.voltdb.stream.api.extension
 
VoltLifecycle - Interface in org.voltdb.stream.api.pipeline
Defines life cycle of the operator.
VoltOpenStreamBuilder<I> - Interface in org.voltdb.stream.api.pipeline
 
VoltPipeline - Interface in org.voltdb.stream.api.pipeline
This is entry point for a volt stream definition.
VoltStream - Interface in org.voltdb.stream.api.extension
 
VoltStreamBuilder - Interface in org.voltdb.stream.api.pipeline
 
VoltStreamException(String) - Constructor for exception class org.voltdb.stream.api.VoltEnvironment.VoltStreamException
 
VoltStreamException(String, Throwable) - Constructor for exception class org.voltdb.stream.api.VoltEnvironment.VoltStreamException
 
VoltStreamExtension - Interface in org.voltdb.stream.api.extension
Convenient place to register any source, sink or function custom implementation - see VoltEnvironment.register(Class, ConfigurableOperatorProducer), by dividing component into configuration and implementation, the system can bind different implementations for testing and other for production.
VoltStreamSink<T> - Interface in org.voltdb.stream.api.pipeline
This class encapsulates any integration logic with a downstream system.
VoltStreamSinkConfigurator<T> - Interface in org.voltdb.stream.api.extension
A stream sink configurator.
VoltStreamSource<T> - Interface in org.voltdb.stream.api.pipeline
This class encapsulates any integration logic with an upstream system.
VoltStreamSourceConfigurator<T> - Interface in org.voltdb.stream.api.extension
A stream source configurator.

W

withName(String) - Method in interface org.voltdb.stream.api.pipeline.VoltStreamBuilder
Sets a name for the stream which will help to identify the stream in other systems, such as metric collecting system, etc.
A B C D E F G H I K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form