A B C D F G H I L M N O P R S T V 

A

AbstractNotificationSource - Class in com.ibm.streams.operator.control.patterns
Abstract operator for listening to notifications from the Job Control Plane and then submitting tuples derived from the notification to an output port.
AbstractNotificationSource() - Constructor for class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
AggregateInfo() - Constructor for class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener.AggregateInfo
 
allPortsReady() - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
Connect this to the Job Control Plane as a Controllable.
allPortsReady() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
allPortsReady() - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
attributeName - Variable in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Attribute being aggregated.
availableProcessors() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Return the number of processors available to the Java virtual machine.

B

BASE_NOTIFY_SCHEMA - Static variable in class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
Base schema that includes all the fixed typed attributes that can be set from a Notification, namely source, notifyType, sequence, ts and message.
batch - Variable in class com.ibm.streams.operator.samples.patterns.TupleConsumer
 
batchSize() - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
Get the batch size to use from the parameter batchSize using 1 if that is not set.

C

checkOuputAttributes(OperatorContextChecker) - Static method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
Check the output attributes name and value are present.
checkPorts(OperatorContextChecker) - Static method in class com.ibm.streams.operator.samples.operators.PortSequencer
 
checkTaggedParameters(OperatorContextChecker) - Static method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
If parameter tagged is set then tags is required.
checkTsAttribute(OperatorContextChecker) - Static method in class com.ibm.streams.operator.samples.sources.RandomBeaconWithTimestamp
Check that the output port schema contains an attribute ts of type timestamp.
com.ibm.streams.flow.samples.javaprimitives - package com.ibm.streams.flow.samples.javaprimitives
Samples of testing Java primitive operators using the test framework.
com.ibm.streams.function.samples.jvm - package com.ibm.streams.function.samples.jvm
Sample SPL Java native functions related to the Java Virtual Machine.
com.ibm.streams.function.samples.math - package com.ibm.streams.function.samples.math
Sample mathematical SPL Java native functions.
com.ibm.streams.operator.control.patterns - package com.ibm.streams.operator.control.patterns
Patterns for operators that use with the Job Control Plane.
com.ibm.streams.operator.samples.operators - package com.ibm.streams.operator.samples.operators
Sample SPL Java primitive operators.
com.ibm.streams.operator.samples.patterns - package com.ibm.streams.operator.samples.patterns
Sample abstract patterns for operators.
com.ibm.streams.operator.samples.sinks - package com.ibm.streams.operator.samples.sinks
Sample SPL Java primitive operators that deliver data to external systems from input streams.
com.ibm.streams.operator.samples.sources - package com.ibm.streams.operator.samples.sources
Sample SPL Java primitive operators that source data as streams.
com.ibm.streams.operator.samples.windows - package com.ibm.streams.operator.samples.windows
Sample window-based SPL Java primitive operators and listeners.
complete() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Complete the operator by canceling the periodic task that calls fetchTuples.
completedTuples() - Method in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
Complete the operator.
cosh(double) - Static method in class com.ibm.streams.function.samples.math.MathFunctions
Returns the hyperbolic cosine of a double value.
count - Variable in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener.AggregateInfo
Number of tuples in the window.

D

DecimalScaleSetter - Class in com.ibm.streams.operator.samples.operators
Set a decimal attribute's scale.
DecimalScaleSetter() - Constructor for class com.ibm.streams.operator.samples.operators.DecimalScaleSetter
 
DecimalSumAggregatorListener - Class in com.ibm.streams.operator.samples.windows
Sample window listener to demonstrate window aggregation on a decimal attribute.
DecimalSumAggregatorListener(StreamWindow<Tuple>, String, StreamingOutput<OutputTuple>) - Constructor for class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
 
DecimalSumAggregatorListener.AggregateInfo - Class in com.ibm.streams.operator.samples.windows
Class for the per-partition state for the aggregate.

F

factorial(int) - Static method in class com.ibm.streams.function.samples.math.MathFunctions
Returns n! (n factorial).
fetchSingleTuple(OutputTuple) - Method in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
Fetch the information for the tuple and set its attributes.
fetchSingleTuple(OutputTuple) - Method in class com.ibm.streams.operator.samples.sources.RandomBeacon
Set each attribute to a random value and then return true to submit the tuple.
fetchSingleTuple(OutputTuple) - Method in class com.ibm.streams.operator.samples.sources.RandomBeaconWithTimestamp
Use the parent-class's fetchSingleTuple and then overwrites the ts attribute's value with a current timestamp.
fetchTuples() - Method in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
Call PollingSingleTupleProducer.fetchSingleTuple(OutputTuple) to allow a sub-class to submit a tuple.
fetchTuples() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Called periodically to fetch tuples from an external source and submit them to the output stream(s).
filter(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.operators.Regex
Execute the regular expressions against any ustring in the incoming tuple.
filter(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
Perform any filtering rules on the incoming tuple.
freeMemory() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Returns the amount of free memory (in bytes) in the Java Virtual Machine.

G

gc() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Request garbage collection for the Java virtual machine.
getAttributes(Notification, Object) - Method in class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
Convert the notification to a Map of attributes keyed by attribute name.
getBatchSize() - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Get the batch size.
getBatchTimeout() - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Get the batch timeout value.
getBatchTimeoutUnit() - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
 
getFilter() - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
getFilters() - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
getInitialDelay() - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Get the initial delay.
getInitialDelayUnit() - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Get the unit of the initial delay.
getInitializedState(Object, DecimalSumAggregatorListener.AggregateInfo) - Method in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Create a new AggregateInfo as the initial state.
getNotificationListener() - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
getnPostErrorCodeResponses() - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
 
getnPostRequests() - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
 
getObjectNames() - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
getOutput() - Method in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
Get the single output.
getOutputSchema() - Method in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
Get the output schema for the single output port.
getPollFrequency() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Get the polling frequency, defaults to 1.
getPollFrequencyUnit() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Get the unit for the polling frequency, defaults to SECONDS.
getPropertiesAndSubmit() - Method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
Iterate over all the system properties submitting a tuple for each name value pair.
getSeed() - Method in class com.ibm.streams.operator.samples.sources.RandomBeacon
 
getSortAttributes() - Method in class com.ibm.streams.operator.samples.windows.TumblingSortOperator
 
getStateHandler(Counter) - Method in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
 
getStateHandler(Counter) - Method in class com.ibm.streams.operator.samples.sources.RandomBeacon
 
getStream() - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer.BatchedTuple
Get the port the tuple arrived on.
getTuple(Notification, Object) - Method in class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
Convert the notification to a tuple, using NotificationTupleSubmitter.getAttributes(Notification, Object).
getTuple() - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer.BatchedTuple
Get the tuple.
getURL() - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
Get the URL for the POST requests from the required parameter url.
getUrlPath() - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
Get the path of the URL as a String.
getVmName() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Returns the Java virtual machine implementation name.
getVmVendor() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Returns the Java virtual machine implementation vendor.
getVmVersion() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Returns the Java virtual machine implementation version.

H

handleEvent(StreamWindowEvent<Tuple>) - Method in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Perform window based aggregation with incremental state updates.
handleNotification(Notification, Object) - Method in class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
Handle the notification by converting notification and {code handback} to a tuple using NotificationTupleSubmitter.getTuple(Notification, Object) and then calling NotificationTupleSubmitter.submit(Tuple).
HttpPOST - Class in com.ibm.streams.operator.samples.sinks
Sink operator where incoming tuples are sent as an HTTP POST requests to the URL specified in the operator specific url parameter.
HttpPOST() - Constructor for class com.ibm.streams.operator.samples.sinks.HttpPOST
 
hypot(double, double) - Static method in class com.ibm.streams.function.samples.math.MathFunctions
Returns √(x2 + y2).

I

IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.patterns.TupleConsumer
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.patterns.TupleProducer
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.sources.RandomBeacon
 
IBM_COPYRIGHT - Static variable in class com.ibm.streams.operator.samples.sources.RandomBeaconWithTimestamp
 
initialize(OperatorContext) - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
 
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.operators.DecimalScaleSetter
Initialize the operator.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.operators.LoggerUseExample
Sample uses of log and trace.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.operators.OrderedPortSequencer
Create a Lock object for each input/output port (remember the class assumes a 1-1 mapping between input and output ports).
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.operators.PortSequencer
Initialize the portSequences field holding the Operator's (this) synchronization to ensure later threads fetching it using getPortSequences() are guaranteed to see the initialized value.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.operators.Regex
Initialize this operator.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.patterns.ProcessTupleProducer
Create the non-daemon thread used to call the process() method.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Initialize this operator.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
Initialize this operator.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
Initialize by setting the URL and the batch size.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.sources.RandomBeacon
Take the seed for the random number generator from the parameter seed if it exists, otherwise use the current time.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
Create the non-daemon thread used to call the process() method.
initialize(OperatorContext) - Method in class com.ibm.streams.operator.samples.windows.TumblingSortOperator
Perform a tumbling sort using the attributes defined by the SPL parameter sortAttributes.
isApplicable(OperatorContext) - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
Is this Controllable applicable for this invocation.
isFlushOnFinal() - Method in class com.ibm.streams.operator.samples.windows.TumblingSortOperator
True if outstanding tuples are submitted when final markers are processed, false if they are discarded.
isPreserveOrder() - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
True if arrival order is to be preserved when processing tuples.

L

LoggerUseExample - Class in com.ibm.streams.operator.samples.operators
Operator that solely demonstrates source code use of java.util.logging.Logger to send messages to the SPL log and trace facilities.
LoggerUseExample() - Constructor for class com.ibm.streams.operator.samples.operators.LoggerUseExample
 

M

matchingPorts(OperatorContextChecker) - Static method in class com.ibm.streams.operator.samples.operators.PassThrough
Verify the output port schema matches all input ports.
MathFunctions - Class in com.ibm.streams.function.samples.math
Sample mathematical SPL Java native functions.
maxMemory() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Returns the maximum amount of memory that the Java virtual machine will attempt to use.
MaxMinOperator - Class in com.ibm.streams.operator.samples.operators
Sample operator that demonstrates the usage of CustomLiteral and Attribute parameters.
MaxMinOperator() - Constructor for class com.ibm.streams.operator.samples.operators.MaxMinOperator
 
MaxMinOperator.Type - Enum in com.ibm.streams.operator.samples.operators
Type of monitoring that is supported
mc - Variable in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Math context used for arithmetic.

N

NotificationTupleSubmitter - Class in com.ibm.streams.operator.control.patterns
Notification listener that submits a tuple to an output port with the attributes set from the Notification.
NotificationTupleSubmitter(OperatorContext, StreamingOutput<?>) - Constructor for class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
Create a NotificationTupleSubmitter

O

OrderedPortSequencer - Class in com.ibm.streams.operator.samples.operators
OrderedPortSequencer extends PortSequencer to provide submission of tuples within a port ordered by the portSequence attribute.
OrderedPortSequencer() - Constructor for class com.ibm.streams.operator.samples.operators.OrderedPortSequencer
 
outputPort - Variable in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Output port tuples containing the aggregate values are delivered to.

P

PassThrough - Class in com.ibm.streams.operator.samples.operators
Simple sample operator that passes all input unchanged from any input port to its single output port.
PassThrough() - Constructor for class com.ibm.streams.operator.samples.operators.PassThrough
 
PollingSingleTupleProducer - Class in com.ibm.streams.operator.samples.patterns
Abstract pattern class for an operator that produces a single tuple periodically on a single output port.
PollingSingleTupleProducer() - Constructor for class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
 
PollingTupleProducer - Class in com.ibm.streams.operator.samples.patterns
Abstract pattern class for an operator that produces tuples by polling an external source for information and converting that information into outgoing tuples.
PollingTupleProducer() - Constructor for class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
 
PortSequencer - Class in com.ibm.streams.operator.samples.operators
Simple class that maintains an per-input port int64 sequence number for arriving tuples and sets it as the portSequence attribute of the output tuple.
PortSequencer() - Constructor for class com.ibm.streams.operator.samples.operators.PortSequencer
 
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.operators.DecimalScaleSetter
Submit each input tuple, modifying the named attribute by setting its scale.
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.operators.MaxMinOperator
 
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.operators.OrderedPortSequencer
Process the tuple and submit it holding the port specific lock for the entire processing of the tuple.
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.operators.PassThrough
Forward the input tuple directly to output port 0.
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.operators.PortSequencer
Process a tuple simply assigning it to the output port with the same index and adding the portSequence field set to the sequence of the arriving tuple within the port.
process() - Method in class com.ibm.streams.operator.samples.patterns.ProcessTupleProducer
Sub-classes provide a process() method that submits tuples on the operator's output ports.
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Process incoming tuples by adding them to the current batch and submitting the batch for execution if required.
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
Called when a tuple is received on the input port.
process() - Method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
 
processBatch(Queue<TupleConsumer.BatchedTuple>) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Process a batch of tuples.
processBatch(Queue<TupleConsumer.BatchedTuple>) - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
Process the batch of incoming tuples by creating a POST request from them of the form name=value.
processPunctuation(StreamingInput<Tuple>, StreamingData.Punctuation) - Method in class com.ibm.streams.operator.samples.operators.PassThrough
Forward the punctuation mark directly to output port 0.
processPunctuation(StreamingInput<Tuple>, StreamingData.Punctuation) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Process any final punctuation by flushing the batch and waiting for all the work to complete.
ProcessTupleProducer - Class in com.ibm.streams.operator.samples.patterns
Abstract pattern class for an operator that produces tuples on output streams using a single process method.
ProcessTupleProducer() - Constructor for class com.ibm.streams.operator.samples.patterns.ProcessTupleProducer
 
producerInitialize() - Method in class com.ibm.streams.operator.samples.patterns.ProcessTupleProducer
Deprecated. 
producerInitialize() - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Deprecated.
Sub-classes should instead override TupleProducer.initialize(OperatorContext) to be consistent with AbstractOperator.

R

rand - Variable in class com.ibm.streams.operator.samples.sources.RandomBeacon
 
randomBeacon() - Method in class com.ibm.streams.flow.samples.javaprimitives.SourceSamples
Create and execute a graph containing a single RandomBeacon operator.
RandomBeacon - Class in com.ibm.streams.operator.samples.sources
Sample source operator that creates a tuple with random values on its single output port according to the defined period.
RandomBeacon() - Constructor for class com.ibm.streams.operator.samples.sources.RandomBeacon
 
randomBeaconParameters() - Method in class com.ibm.streams.flow.samples.javaprimitives.SourceSamples
Create a RandomBeacon and verify its parameters are set correctly.
RandomBeaconWithTimestamp - Class in com.ibm.streams.operator.samples.sources
Sample source operator that creates a tuple with random values and a timestamp.
RandomBeaconWithTimestamp() - Constructor for class com.ibm.streams.operator.samples.sources.RandomBeaconWithTimestamp
 
Regex - Class in com.ibm.streams.operator.samples.operators
Sample operator that using regular expressions to filter tuples.
Regex() - Constructor for class com.ibm.streams.operator.samples.operators.Regex
 
requireTumblingWindow(OperatorContextChecker) - Static method in class com.ibm.streams.operator.samples.windows.TumblingSortOperator
Check the input port is tumbling.
runFinalization() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Request running of Object.finalize() for objects pending garbage collection in the Java virtual machine.

S

setBatchSize(int) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Set the current batch size.
setBatchTimeout(long, TimeUnit) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Set the batch timeout.
setFilters(String[]) - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
Set the filters.
setFlushOnFinal(boolean) - Method in class com.ibm.streams.operator.samples.windows.TumblingSortOperator
Flush sort buffer when final punctuation mark is processed.
setInitDelay(long) - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Set the initial delay from the operator parameter initDelay in seconds.
setInitDelay(double) - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Set the initial delay in seconds.
setInitialDelay(long, TimeUnit) - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Set the initial delay for processing tuples from the external source.
setIterations(int) - Method in class com.ibm.streams.operator.samples.patterns.PollingSingleTupleProducer
Set the number of iterations.
setMonitoredAttr(TupleAttribute<Tuple, Integer>) - Method in class com.ibm.streams.operator.samples.operators.MaxMinOperator
 
setMonitorType(MaxMinOperator.Type) - Method in class com.ibm.streams.operator.samples.operators.MaxMinOperator
 
setName(String) - Method in class com.ibm.streams.operator.samples.operators.DecimalScaleSetter
Set the name for the decimal attribute.
setnPostErrorCodeResponses(Metric) - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
 
setnPostRequests(Metric) - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
 
setObjectNames(String[]) - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
Set the object names to listen to.
setPatterns(List<String>) - Method in class com.ibm.streams.operator.samples.operators.Regex
Set the patterns used to filter tuples.
setPeriod(double) - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Sets the polling period in seconds from the optional operator parameter float64 parameter period.
setPollFrequency(long, TimeUnit) - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Set the polling frequency.
setPreserveOrder(boolean) - Method in class com.ibm.streams.operator.samples.patterns.TupleConsumer
Set if order of tuples is preserved in the batch and in the calls to processBatch.
setScale(int) - Method in class com.ibm.streams.operator.samples.operators.DecimalScaleSetter
Set the scale for the decimal value.
setSeed(long) - Method in class com.ibm.streams.operator.samples.sources.RandomBeacon
 
setSortAttributes(List<String>) - Method in class com.ibm.streams.operator.samples.windows.TumblingSortOperator
Names of the attributes to perform the sort on.
setTagged(String) - Method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
Set the tagged parameter.
setTags(List<String>) - Method in class com.ibm.streams.operator.samples.sources.SystemPropertySource
Set the tags parameter.
setup(MBeanServerConnection, OperatorContext) - Method in class com.ibm.streams.operator.control.patterns.AbstractNotificationSource
Add the notification listener to each MBean listed in the getObjectNames() array using the filter.
setupOutputTuple(OutputTuple, DecimalSumAggregatorListener.AggregateInfo) - Method in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Set attributes in the tuple representing the aggregation.
setUrlPath(String) - Method in class com.ibm.streams.operator.samples.sinks.HttpPOST
Set the path of the URL as a String, from the operator parameter.
shutdown() - Method in class com.ibm.streams.operator.samples.operators.LoggerUseExample
Example use of a standard Logger methods to trace method entry and exit.
shutdown() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Complete this operator by canceling the periodic task that implements the polling.
shutdown() - Method in class com.ibm.streams.operator.samples.patterns.ProcessTupleProducer
Shutdown this operator, which will interrupt the thread executing the process() method.
shutdown() - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Cancel the startProcessing() task if it was asynchronously kicked off due to an initial delay and has not yet started.
sinh(double) - Static method in class com.ibm.streams.function.samples.math.MathFunctions
Returns the hyperbolic sine of a double value.
SourceSamples - Class in com.ibm.streams.flow.samples.javaprimitives
Collection of sample tests for source operators using the test framework.
SourceSamples() - Constructor for class com.ibm.streams.flow.samples.javaprimitives.SourceSamples
 
startProcessing() - Method in class com.ibm.streams.operator.samples.patterns.PollingTupleProducer
Instead of using TupleProducer.startProcessing to implement the initial delay, use the delay parameter of ScheduledExecutorService.scheduleAtFixedRate.
startProcessing() - Method in class com.ibm.streams.operator.samples.patterns.ProcessTupleProducer
Starts processing by starting the thread that will call process().
startProcessing() - Method in class com.ibm.streams.operator.samples.patterns.TupleProducer
Called to indicate that the operator can start submitting tuples.
submit(Tuple) - Method in class com.ibm.streams.operator.control.patterns.NotificationTupleSubmitter
Asynchronously submit the tuple to the output port.
submitAggregateOutput(DecimalSumAggregatorListener.AggregateInfo) - Method in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener
Submit the aggregate tuple for this partition.
sum - Variable in class com.ibm.streams.operator.samples.windows.DecimalSumAggregatorListener.AggregateInfo
Sum of the attribute's value for tuples in the window.
SystemFunctions - Class in com.ibm.streams.function.samples.jvm
 
SystemPropertySource - Class in com.ibm.streams.operator.samples.sources
Sample source operator using a process() method.
SystemPropertySource() - Constructor for class com.ibm.streams.operator.samples.sources.SystemPropertySource
 

T

tanh(double) - Static method in class com.ibm.streams.function.samples.math.MathFunctions
Returns the hyperbolic tangent of a double value.
totalMemory() - Static method in class com.ibm.streams.function.samples.jvm.SystemFunctions
Returns the total amount of memory in the Java virtual machine.
transform(StreamingInput<Tuple>, Tuple, OutputTuple) - Method in class com.ibm.streams.operator.samples.operators.Regex
Simply assign the input tuple to the output tuple which will copy across the values for any matching Attributes, regardless of position in the StreamSchema.
transform(StreamingInput<Tuple>, Tuple, OutputTuple) - Method in class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
Perform any required transformation.
TumblingSortOperator - Class in com.ibm.streams.operator.samples.windows
Sample ascending sort operator for a tumbling window.
TumblingSortOperator() - Constructor for class com.ibm.streams.operator.samples.windows.TumblingSortOperator
 
TupleConsumer - Class in com.ibm.streams.operator.samples.patterns
Abstract pattern class for an operator that consumes tuples and does not produce an output stream.
TupleConsumer() - Constructor for class com.ibm.streams.operator.samples.patterns.TupleConsumer
 
TupleConsumer.BatchedTuple - Class in com.ibm.streams.operator.samples.patterns
A batched tuple representing the tuple and the port it arrived on.
TupleInTupleOut - Class in com.ibm.streams.operator.samples.patterns
Abstract pattern class for an operator that receives a tuple and then optionally submits a tuple.
TupleInTupleOut() - Constructor for class com.ibm.streams.operator.samples.patterns.TupleInTupleOut
 
TupleProducer - Class in com.ibm.streams.operator.samples.patterns
Abstract pattern class for an operator that produces tuples (a source operator) and typically does not support input ports.
TupleProducer() - Constructor for class com.ibm.streams.operator.samples.patterns.TupleProducer
 

V

valueOf(String) - Static method in enum com.ibm.streams.operator.samples.operators.MaxMinOperator.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.ibm.streams.operator.samples.operators.MaxMinOperator.Type
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D F G H I L M N O P R S T V