A B C D E F G H I J K L M N O P R S T U V W X 

A

AbstractTestClass - Class in com.ibm.streamsx.topology.tester.junit
Test class providing utilities for testing of topologies.
AbstractTestClass() - Constructor for class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
accept(File) - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
 
accept(T) - Method in interface com.ibm.streamsx.topology.function.Consumer
 
add(Tuple) - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
Add a tuple to expected list.
addAsTuple(Object...) - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
Add a tuple to expected list.
addClassDependency(Class<?>) - Method in class com.ibm.streamsx.topology.Topology
Ensures that a class file is loaded into the application's runtime.
addClassLibraries(String[]) - Method in interface com.ibm.streamsx.topology.function.FunctionContext
Add class libraries to the functional class loader.
addFileDependency(String, String) - Method in class com.ibm.streamsx.topology.Topology
Add file or directory tree location to directory dstDirName in the application bundle, making it available to the topology's SPL operators at runtime - e.g., an operator configuration file in "etc" in the application directory.
addJarDependency(String) - Method in class com.ibm.streamsx.topology.Topology
Includes a jar file, specified by the location String, into the application runtime.
addJobControlPlane() - Method in class com.ibm.streamsx.topology.Topology
Add job control plane to this topology.
addResourceTags(String...) - Method in interface com.ibm.streamsx.topology.context.Placeable
Add required resource tags for this topology element for distributed submission.
addSubmissionParameter(String, boolean) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
addSubmissionParameter(String, String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
addSubmissionParameter(String, Number) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
addToConfig(Map<String, Object>) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
addToolkit(TopologyElement, File) - Static method in class com.ibm.streamsx.topology.spl.SPL
Add a dependency on an SPL toolkit.
addToolkitDependency(TopologyElement, String, String) - Static method in class com.ibm.streamsx.topology.spl.SPL
Add a logical dependency on an SPL toolkit.
aggregate(Function<List<T>, A>) - Method in interface com.ibm.streamsx.topology.TWindow
Declares a stream that containing tuples that represent an aggregation of this window.
aggregate(Function<List<T>, A>, long, TimeUnit) - Method in interface com.ibm.streamsx.topology.TWindow
Declares a stream that containing tuples that represent an aggregation of this window.
all(Condition<?>...) - Static method in interface com.ibm.streamsx.topology.tester.Condition
Return a condition that is true if all conditions are valid.
AnalyticsServiceProperties - Interface in com.ibm.streamsx.topology.context
 
and(Condition<?>...) - Method in interface com.ibm.streamsx.topology.tester.Condition
Return a condition that is true if this AND all conditions are valid.
APP_DIR - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Location of the generated application directory when creating a Streams application bundle.
apply(T1, T2) - Method in interface com.ibm.streamsx.topology.function.BiFunction
 
apply(T) - Method in interface com.ibm.streamsx.topology.function.Function
 
apply(String) - Method in class com.ibm.streamsx.topology.json.JSONStreams.DeserializeJSON
 
apply(JSONObject) - Method in class com.ibm.streamsx.topology.json.JSONStreams.SerializeJSON
 
apply(JSONAble) - Method in class com.ibm.streamsx.topology.json.JSONStreams.ToJSON
 
apply(T) - Method in class com.ibm.streamsx.topology.logic.Identity
Returns the input value.
apply(Long) - Method in class com.ibm.streamsx.topology.streams.BeaconStreams.BeaconFunction
 
apply(C) - Method in class com.ibm.streamsx.topology.streams.CollectionStreams.FlattenCollection
Just returns the collection, TStream.multiTransform(Function) will actually perform the flattening.
apply(M) - Method in class com.ibm.streamsx.topology.streams.CollectionStreams.FlattenMap
 
applyAsInt(T) - Method in interface com.ibm.streamsx.topology.function.ToIntFunction
Apply the function to the tuple and return an int.
assertTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
asType(Class<T>) - Method in interface com.ibm.streamsx.topology.TStream
Return a strongly typed reference to this stream.
atLeastTupleCount(TStream<?>, long) - Method in interface com.ibm.streamsx.topology.tester.Tester
Return a condition that evaluates if stream has submitted at least expectedCount number of tuples.
autonomous() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Return a stream matching this stream whose subsequent processing will execute in an autonomous region.
autonomous() - Method in interface com.ibm.streamsx.topology.TStream
Return a stream matching this stream whose subsequent processing will execute in an autonomous region.

B

beacon(TopologyElement) - Static method in class com.ibm.streamsx.topology.streams.BeaconStreams
Creates an infinite source stream of tuples with no delay between each tuple.
beacon(TopologyElement, long) - Static method in class com.ibm.streamsx.topology.streams.BeaconStreams
Creates a source stream of count tuples with no delay between each tuple.
BeaconFunction() - Constructor for class com.ibm.streamsx.topology.streams.BeaconStreams.BeaconFunction
 
BeaconStreams - Class in com.ibm.streamsx.topology.streams
Utilities for beacon streams.
BeaconStreams() - Constructor for class com.ibm.streamsx.topology.streams.BeaconStreams
 
BeaconStreams.BeaconFunction - Class in com.ibm.streamsx.topology.streams
 
BeaconTuple - Class in com.ibm.streamsx.topology.tuple
Tuple type issued by a beacon stream.
BeaconTuple(long) - Constructor for class com.ibm.streamsx.topology.tuple.BeaconTuple
Create a BeaconTuple with the current time.
BeaconTuple(long, long) - Constructor for class com.ibm.streamsx.topology.tuple.BeaconTuple
Create a BeaconTuple.
BiFunction<T1,T2,R> - Interface in com.ibm.streamsx.topology.function
A function that is passed two arguments and returns a value.
BLOB - Static variable in interface com.ibm.streamsx.topology.spl.SPLSchemas
SPL schema used by TStream<com.ibm.streams.operator.types.Blob> streams.
builder() - Method in class com.ibm.streamsx.topology.Topology
 
builder() - Method in interface com.ibm.streamsx.topology.TopologyElement
Get the underlying OperatorGraph.

C

checkMaximumVersion(String, int...) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
Only run a test at a specific maximum version or lower.
checkMinimumVersion(String, int...) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
Only run a test at a specific minimum version or higher.
checkpointPeriod(long, TimeUnit) - Method in class com.ibm.streamsx.topology.Topology
Checkpoint the state of the graph periodically.
CollectionStreams - Class in com.ibm.streamsx.topology.streams
Utilities for streams tuples that are collections of values.
CollectionStreams() - Constructor for class com.ibm.streamsx.topology.streams.CollectionStreams
 
CollectionStreams.FlattenCollection<C extends java.util.Collection<T>,T> - Class in com.ibm.streamsx.topology.streams
Function that flattens a collection when passed to TStream.multiTransform(Function).
CollectionStreams.FlattenMap<M extends java.util.Map<K,V>,K,V> - Class in com.ibm.streamsx.topology.streams
 
colocate(Placeable<?>...) - Method in interface com.ibm.streamsx.topology.context.Placeable
Colocate this element with other topology elements so that at runtime they all execute within the same operating system process.
com.ibm.streamsx.topology - package com.ibm.streamsx.topology
Java application API for IBM Streams.
com.ibm.streamsx.topology.consistent - package com.ibm.streamsx.topology.consistent
At least once processing using consistent regions.
com.ibm.streamsx.topology.context - package com.ibm.streamsx.topology.context
Context for executing IBM Streams Java topologies.
com.ibm.streamsx.topology.context.remote - package com.ibm.streamsx.topology.context.remote
 
com.ibm.streamsx.topology.file - package com.ibm.streamsx.topology.file
File related streams.
com.ibm.streamsx.topology.function - package com.ibm.streamsx.topology.function
Classes that provide the mechanisms to implement functional transformations on streams.
com.ibm.streamsx.topology.generator.functional - package com.ibm.streamsx.topology.generator.functional
 
com.ibm.streamsx.topology.generator.operator - package com.ibm.streamsx.topology.generator.operator
 
com.ibm.streamsx.topology.inet - package com.ibm.streamsx.topology.inet
Network access to streaming data.
com.ibm.streamsx.topology.jobconfig - package com.ibm.streamsx.topology.jobconfig
 
com.ibm.streamsx.topology.json - package com.ibm.streamsx.topology.json
JSON streams.
com.ibm.streamsx.topology.logic - package com.ibm.streamsx.topology.logic
Utilities and implementations of functional logic.
com.ibm.streamsx.topology.messaging.kafka - package com.ibm.streamsx.topology.messaging.kafka
Support for integrating with the Apache Kafka messaging system http://kafka.apache.org.
com.ibm.streamsx.topology.messaging.mqtt - package com.ibm.streamsx.topology.messaging.mqtt
Support for integrating with the MQTT messaging system http://mqtt.org.
com.ibm.streamsx.topology.spl - package com.ibm.streamsx.topology.spl
Integration between Streams SPL and Java applications.
com.ibm.streamsx.topology.streams - package com.ibm.streamsx.topology.streams
Utilities to create and transform streams.
com.ibm.streamsx.topology.tester - package com.ibm.streamsx.topology.tester
Support for testing of topologies.
com.ibm.streamsx.topology.tester.junit - package com.ibm.streamsx.topology.tester.junit
 
com.ibm.streamsx.topology.tester.spl - package com.ibm.streamsx.topology.tester.spl
 
com.ibm.streamsx.topology.tuple - package com.ibm.streamsx.topology.tuple
Interfaces for tuple types.
compareTo(BeaconTuple) - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
 
COMPILE_INSTALL_DIR - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Override IBM Streams install directory for bundle compilation, defaults to $STREAMS_INSTALL.
complete(Tester, Condition<?>, long, TimeUnit) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
Test a topology that may run forever.
complete(StreamsContext<?>) - Method in interface com.ibm.streamsx.topology.tester.Tester
Submit the topology for this tester and wait for it to complete.
complete(StreamsContext<?>, Condition<?>, long, TimeUnit) - Method in interface com.ibm.streamsx.topology.tester.Tester
Submit the topology for this tester and wait for it to complete, or reach an end condition.
complete(StreamsContext<?>, Map<String, Object>, Condition<?>, long, TimeUnit) - Method in interface com.ibm.streamsx.topology.tester.Tester
 
completeAndTestStringOutput(StreamsContext<?>, TStream<?>, long, TimeUnit, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
 
completeAndTestStringOutput(StreamsContext<?>, Map<String, Object>, TStream<?>, long, TimeUnit, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
 
Condition<T> - Interface in com.ibm.streamsx.topology.tester
A test condition on a stream.
CONFIG - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
Configuration for a submitted application.
CONFIG - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
JSON attribute for operator configuration.
connectTo(BOperatorInvocation, boolean, BInputPort) - Method in interface com.ibm.streamsx.topology.TStream
Internal method.
ConsistentRegionConfig - Class in com.ibm.streamsx.topology.consistent
Immutable consistent region configuration.
ConsistentRegionConfig() - Constructor for class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Create a ConsistentRegionConfig.Trigger.OPERATOR_DRIVEN consistent region configuration.
ConsistentRegionConfig(int) - Constructor for class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Create a ConsistentRegionConfig.Trigger.PERIODIC consistent region configuration.
ConsistentRegionConfig.Trigger - Enum in com.ibm.streamsx.topology.consistent
Defines how the drain-checkpoint cycle of a consistent region is triggered.
constants(List<T>) - Method in class com.ibm.streamsx.topology.Topology
Create a stream containing all the tuples in data.
Consumer<T> - Interface in com.ibm.streamsx.topology.function
A function that takes an argument and returns nothing.
contains(TStream<String>, String) - Static method in class com.ibm.streamsx.topology.streams.StringStreams
Create a filtered stream that contains String tuples containing a specific term.
contents(SPLStream) - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
Create a condition for stream having the tuples ExpectedTuples.getTuples() in the same order.
ContextProperties - Interface in com.ibm.streamsx.topology.context
Properties that can be specified when submitting the topology to a context.
convert(Function<Tuple, T>) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Convert SPL tuples into Java objects.
convertStream(TStream<T>, BiFunction<T, OutputTuple, OutputTuple>, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Convert a Stream to an SPLStream.
createSubmissionParameter(Topology, String, Object, boolean) - Static method in class com.ibm.streamsx.topology.spl.SPL
Create a submission parameter with or without a default value.
createSubmissionParameter(String, Class<T>) - Method in class com.ibm.streamsx.topology.Topology
Create a submission parameter without a default value.
createSubmissionParameter(String, T) - Method in class com.ibm.streamsx.topology.Topology
Create a submission parameter with a default value.
createValue(T, Type.MetaType) - Static method in class com.ibm.streamsx.topology.spl.SPL
Create a SPL value wrapper object for the specified SPL MetaType.
csvCompressedReader(TStream<String>, StreamSchema, FileSPLStreams.Compression) - Static method in class com.ibm.streamsx.topology.spl.FileSPLStreams
Create an SPLStream using the spl.adapter::FileSource operator that reads CSV records from compressed files with names delivered by fileNames.
csvReader(TStream<String>, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.FileSPLStreams
Create an SPLStream using the spl.adapter::FileSource operator that reads CSV records from files with names delivered by fileNames.

D

DATA_DIRECTORY - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
Location of the submitted application's data directory.
deserialize(TStream<String>) - Static method in class com.ibm.streamsx.topology.json.JSONStreams
Declare a stream of JSON objects from a stream of serialized JSON tuples.
DeserializeJSON() - Constructor for class com.ibm.streamsx.topology.json.JSONStreams.DeserializeJSON
 
DirectoryWatcher - Class in com.ibm.streamsx.topology.file
 
DirectoryWatcher() - Constructor for class com.ibm.streamsx.topology.file.DirectoryWatcher
 
directoryWatcher(TopologyElement, String) - Static method in class com.ibm.streamsx.topology.file.FileStreams
Creates a stream of absolute newly created file names from watching directory.
drainTimeout(long) - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Return a new configuration changing drainTimeout.

E

endlessSource(Supplier<T>) - Method in class com.ibm.streamsx.topology.Topology
Declare an endless source stream.
endlessSourceN(Function<Long, T>) - Method in class com.ibm.streamsx.topology.Topology
Declare an endless source stream.
endLowLatency() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Return a TStream that is no longer guaranteed to run in the same process as the calling stream.
endLowLatency() - Method in interface com.ibm.streamsx.topology.TStream
Return a TStream that is no longer guaranteed to run in the same process as the calling stream.
endParallel() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Ends a parallel region by merging the channels into a single stream.
endParallel() - Method in interface com.ibm.streamsx.topology.TStream
Ends a parallel region by merging the channels into a single stream.
equals(Object) - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
 
equals(Object) - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
 
equals(Object) - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
 
ExpectedTuples - Class in com.ibm.streamsx.topology.tester.spl
List of expected tuples.
ExpectedTuples(StreamSchema) - Constructor for class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
Create an initially empty ExpectedTuples.

F

FileSPLStreams - Class in com.ibm.streamsx.topology.spl
Creation of SPLStreams that relate to files.
FileSPLStreams() - Constructor for class com.ibm.streamsx.topology.spl.FileSPLStreams
 
FileSPLStreams.Compression - Enum in com.ibm.streamsx.topology.spl
 
FileStreams - Class in com.ibm.streamsx.topology.file
Utilities for file system related streams.
FileStreams() - Constructor for class com.ibm.streamsx.topology.file.FileStreams
 
filter(Predicate<Tuple>) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Declare a new stream that filters tuples from this stream.
filter(Predicate<T>) - Method in interface com.ibm.streamsx.topology.TStream
Declare a new stream that filters tuples from this stream.
finalizeGraph(StreamsContext.Type) - Method in class com.ibm.streamsx.topology.Topology
Resolves the jar dependencies, sets the respective parameters.
first(BiFunction<T, U, R>) - Static method in class com.ibm.streamsx.topology.logic.Logic
Wrap a BiFunction instance that operators on a single value for the second parameter (type U) as a BiFunction that takes an List.
flatten(TStream<C>) - Static method in class com.ibm.streamsx.topology.streams.CollectionStreams
' Flatten a stream containing collections into a stream containing the individual elements.
flattenArray(TStream<JSONObject>, String, String...) - Static method in class com.ibm.streamsx.topology.json.JSONStreams
Declare a stream that flattens an array present in the input tuple.
FlattenCollection() - Constructor for class com.ibm.streamsx.topology.streams.CollectionStreams.FlattenCollection
 
flattenMap(TStream<M>) - Static method in class com.ibm.streamsx.topology.streams.CollectionStreams
 
FlattenMap() - Constructor for class com.ibm.streamsx.topology.streams.CollectionStreams.FlattenMap
 
FORCE_REMOTE_BUILD - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Flag to be supplied to force the compilation to occur on a Bluemix instance, if possible.
fromProperties(Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Create a JobConfig from a configuration map.
Function<T,R> - Interface in com.ibm.streamsx.topology.function
A function that is passed an argument and returns a value.
FUNCTIONAL_LOGIC_PARAM - Static variable in interface com.ibm.streamsx.topology.generator.functional.FunctionalOpProperties
 
FunctionalOpProperties - Interface in com.ibm.streamsx.topology.generator.functional
 
FunctionContainer - Interface in com.ibm.streamsx.topology.function
Container for a function executing in a IBM Streams application.
FunctionContext - Interface in com.ibm.streamsx.topology.function
Context for a function executing in a IBM Streams application.

G

get() - Method in interface com.ibm.streamsx.topology.function.Supplier
 
get() - Method in class com.ibm.streamsx.topology.logic.Value
Return the constant value.
getChannel() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
Get the index of the parallel channel the function is on.
getConfig() - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
Get the connector's KafkaConsumer configuration information.
getConfig() - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaProducer
Get the connector's KafkaProducer configuration information.
getConfig() - Method in class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
Get the connector's configuration information.
getConfig() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
getConfig() - Method in class com.ibm.streamsx.topology.Topology
 
getConfiguredHost() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
Get the host this container is executing on.
getContainer() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
Get the container hosting a function
getDataDirectory() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Get the data directory.
getDefaultTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
getDefaultTimeout() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
getDependencyResolver() - Method in class com.ibm.streamsx.topology.Topology
Internal use only.
getDirectory() - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
 
getDomainId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
Return the IBM Streams domain identifier for this container.
getDrainTimeout() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Get the drain timeout for this configuration.
getEmbedded() - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
 
getEncoding() - Method in class com.ibm.streamsx.topology.file.TextFileReader
 
getId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
Get the runtime identifier for this container.
getInstanceId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
Return the IBM Streams instance identifier for this container.
getJobGroup() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Get the job group.
getJobId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
Get the runtime identifier for this container's running job.
getJobName() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Get the job name.
getJSON(TopologyElement, String, long, TimeUnit) - Static method in class com.ibm.streamsx.topology.inet.HTTPStreams
Periodically poll a web service using HTTP GET for application/json data.
getKey() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
Get the key (sequence identifier) of this tuple.
getKey() - Method in interface com.ibm.streamsx.topology.tuple.Keyable
Returns the partition key for this tuple.
getKey() - Method in interface com.ibm.streamsx.topology.tuple.Message
Get the message key for this object.
getKey() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
 
getMaxChannels() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
Get the total number of parallel channels for the parallel region that the function is in.
getMaxConsecutiveResetAttempts() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Get the maximum number of consecutive reset attempts.
getMessage() - Method in interface com.ibm.streamsx.topology.tuple.Message
Get the message content for this object.
getMessage() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
 
getName() - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
getName() - Method in class com.ibm.streamsx.topology.Topology
Name of this topology.
getOverrideResourceLoadProtection() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
getPeriod() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Get the trigger period.
getPreloadApplicationBundles() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
getRelaunchCount() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
Return the number of times this container has been relaunched.
getRemoteContext(String) - Static method in class com.ibm.streamsx.topology.context.remote.RemoteContextFactory
 
getRemoteContext(RemoteContext.Type) - Static method in class com.ibm.streamsx.topology.context.remote.RemoteContextFactory
 
getResetTimeout() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Get the reset timeout for this configuration.
getResourceTags() - Method in interface com.ibm.streamsx.topology.context.Placeable
Get the set of resource tags this element requires.
getResult() - Method in interface com.ibm.streamsx.topology.tester.Condition
Get the result for this condition.
getScheduledExecutorService() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
Return a scheduler to execute background tasks.
getSchema() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
SPL schema of this stream.
getSchema() - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
Get the schema of the tuples.
getSequence() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
Get the sequence identifier of this tuple.
getStream() - Method in interface com.ibm.streamsx.topology.spl.SPLInput
 
getStream() - Method in interface com.ibm.streamsx.topology.spl.SPLWindow
SPL stream for this window.
getStream() - Method in interface com.ibm.streamsx.topology.TWindow
Get this window's stream.
getStreamsContext(String) - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
 
getStreamsContext(StreamsContext.Type) - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
 
getStreamsTracing() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
getSubmissionParameters() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Get the submission parameters.
getTester() - Method in class com.ibm.streamsx.topology.Topology
Get the tester for this topology.
getTesterContext() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
Return the default context for tests.
getTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
getThreadFactory() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
Return a ThreadFactory that can be used by the function with the thread context class loader set correctly.
getTime() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
Get the time of this tuple.
getTimeUnit() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
getTopic() - Method in interface com.ibm.streamsx.topology.tuple.Message
Get the message topic for this object.
getTopic() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
 
getTopology() - Method in interface com.ibm.streamsx.topology.tester.Tester
Get the topology for this tester.
getTracing() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
getTrigger() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Get the trigger type.
getTupleClass() - Method in interface com.ibm.streamsx.topology.TStream
Class of the tuples on this stream, if known.
getTupleClass() - Method in interface com.ibm.streamsx.topology.TWindow
Class of the tuples in this window.
getTuples() - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
Get the current of tuples.
getTupleType() - Method in interface com.ibm.streamsx.topology.TStream
Type of the tuples on this stream.
getTupleType() - Method in interface com.ibm.streamsx.topology.TWindow
Type of the tuples in this window.
getType() - Method in interface com.ibm.streamsx.topology.context.remote.RemoteContext
The type of this context.
getType() - Method in interface com.ibm.streamsx.topology.context.StreamsContext
The type of this context.
getValue() - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
graph() - Method in class com.ibm.streamsx.topology.Topology
Get the underlying OperatorGraph.
graph() - Method in interface com.ibm.streamsx.topology.TopologyElement
Get the underlying OperatorGraph.
GROUP - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
Group name for a submitted application.

H

hashCode() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
 
hashCode() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
 
hashCode() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
 
hasSubmissionParameters() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Have any submission parameters been added.
hasTester() - Method in class com.ibm.streamsx.topology.Topology
Has the tester been created for this topology.
HTTPStreams - Class in com.ibm.streamsx.topology.inet
Access to data in web servers or services using HTTP.
HTTPStreams() - Constructor for class com.ibm.streamsx.topology.inet.HTTPStreams
 

I

identifyStreamsxMessagingVer() - Static method in class com.ibm.streamsx.topology.messaging.kafka.Util
 
Identity<T> - Class in com.ibm.streamsx.topology.logic
Identity unary function that returns its input.
Identity() - Constructor for class com.ibm.streamsx.topology.logic.Identity
 
identity() - Static method in class com.ibm.streamsx.topology.logic.Logic
 
Initializable - Interface in com.ibm.streamsx.topology.function
Optional interface that a function can implement to perform initialization.
initialize(OperatorContext) - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
 
initialize(OperatorContext) - Method in class com.ibm.streamsx.topology.file.TextFileReader
 
initialize(FunctionContext) - Method in interface com.ibm.streamsx.topology.function.Initializable
 
invokeJavaPrimitive(Class<? extends Operator>, SPLInput, StreamSchema, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.JavaPrimitive
Create an SPLStream from the invocation of an SPL Java primitive operator with a single input port & output port.
invokeJavaPrimitive(TopologyElement, Class<? extends Operator>, List<? extends SPLInput>, List<StreamSchema>, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.JavaPrimitive
Invoke an SPL Java primitive operator with an arbitrary number of input and output ports.
invokeJavaPrimitiveSink(Class<? extends Operator>, SPLInput, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.JavaPrimitive
Invocation of a Java primitive operator that consumes a Stream.
invokeJavaPrimitiveSource(TopologyElement, Class<? extends Operator>, StreamSchema, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.JavaPrimitive
Invocation of a Java primitive source operator to produce a SPL Stream.
invokeOperator(String, SPLInput, StreamSchema, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.SPL
Create an SPLStream from the invocation of an SPL operator that consumes a stream.
invokeOperator(String, String, SPLInput, StreamSchema, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.SPL
Create an SPLStream from the invocation of an SPL operator that consumes a stream and produces a stream.
invokeOperator(TopologyElement, String, String, List<? extends SPLInput>, List<StreamSchema>, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.SPL
Invoke an SPL operator with an arbitrary number of input and output ports.
invokeSink(String, SPLInput, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.SPL
Invocation an SPL operator that consumes a Stream.
invokeSink(String, String, SPLInput, Map<String, ? extends Object>) - Static method in class com.ibm.streamsx.topology.spl.SPL
Invocation an SPL operator that consumes a Stream.
invokeSource(TopologyElement, String, Map<String, Object>, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.SPL
Invocation an SPL source operator to produce a Stream.
isKeyed() - Method in interface com.ibm.streamsx.topology.TWindow
Is the window keyed.
isolate() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Return a stream whose immediate subsequent processing will execute in a separate operating system process from this stream's processing.
isolate() - Method in interface com.ibm.streamsx.topology.TStream
Return a stream whose immediate subsequent processing will execute in a separate operating system process from this stream's processing.
isPlaceable() - Method in interface com.ibm.streamsx.topology.context.Placeable
Can this element have placement directives applied to it.
isSupported(Topology) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
Answers if this StreamsContext supports execution of the topology.

J

JavaPrimitive - Class in com.ibm.streamsx.topology.spl
Integration between Java topologies and SPL Java primitive operators.
JavaPrimitive() - Constructor for class com.ibm.streamsx.topology.spl.JavaPrimitive
 
JobConfig - Class in com.ibm.streamsx.topology.jobconfig
A job configuration.
JobConfig() - Constructor for class com.ibm.streamsx.topology.jobconfig.JobConfig
An empty job configuration.
JobConfig(String, String) - Constructor for class com.ibm.streamsx.topology.jobconfig.JobConfig
Job configuration with a job name and group.
JobProperties - Interface in com.ibm.streamsx.topology.context
Job properties specific to distributed contexts.
join(TWindow<U, ?>, BiFunction<T, List<U>, J>) - Method in interface com.ibm.streamsx.topology.TStream
Join this stream with window of type U.
join(Function<T, K>, TWindow<U, K>, BiFunction<T, List<U>, J>) - Method in interface com.ibm.streamsx.topology.TStream
Join this stream with a partitioned window of type U with key type K.
joinLast(Function<? super T, ? extends K>, TStream<U>, Function<? super U, ? extends K>, BiFunction<T, U, J>) - Method in interface com.ibm.streamsx.topology.TStream
Join this stream with the last tuple seen on a stream of type U with partitioning.
joinLast(TStream<U>, BiFunction<T, U, J>) - Method in interface com.ibm.streamsx.topology.TStream
Join this stream with the last tuple seen on a stream of type U.
JSON - Static variable in interface com.ibm.streamsx.topology.json.JSONSchemas
IBM Streams schema used for streams with JSON data.
JSON - Static variable in interface com.ibm.streamsx.topology.spl.SPLSchemas
SPL schema used to publish and subscribe to TStream<JSONObject> streams.
JSONAble - Interface in com.ibm.streamsx.topology.tuple
 
JSONSchemas - Interface in com.ibm.streamsx.topology.json
SPL schema for JSON.
JSONStreams - Class in com.ibm.streamsx.topology.json
Utilities for JSON streams.
JSONStreams() - Constructor for class com.ibm.streamsx.topology.json.JSONStreams
 
JSONStreams.DeserializeJSON - Class in com.ibm.streamsx.topology.json
Function to deserialize a String to a JSONObject.
JSONStreams.SerializeJSON - Class in com.ibm.streamsx.topology.json
Function to serialize a JSONObject to a String.
JSONStreams.ToJSON<T extends JSONAble> - Class in com.ibm.streamsx.topology.json
Function to convert a JSONAble tuple to a JSONObject, using JSONAble.toJSON().

K

KafkaConsumer - Class in com.ibm.streamsx.topology.messaging.kafka
A simple connector to an Apache Kafka cluster for consuming Kafka messages -- subscribing to Kafka topics and creating a TStream<Message>.
KafkaConsumer(TopologyElement, Map<String, Object>) - Constructor for class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
Create a consumer connector for subscribing to topics.
KafkaProducer - Class in com.ibm.streamsx.topology.messaging.kafka
A simple connector to an Apache Kafka cluster for producing Kafka messages -- publishing a TStream<Message> to Kafka topics.
KafkaProducer(TopologyElement, Map<String, Object>) - Constructor for class com.ibm.streamsx.topology.messaging.kafka.KafkaProducer
Create a producer connector for publishing tuples.
KEEP_ARTIFACTS - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Keep any intermediate artifacts.
key(Function<? super T, ? extends U>) - Method in interface com.ibm.streamsx.topology.TWindow
Return a keyed (partitioned) window that has the same configuration as this window with the each tuple's key defined by a function.
key() - Method in interface com.ibm.streamsx.topology.TWindow
Return a keyed (partitioned) window that has the same configuration as this window with each tuple being the key.
Keyable<K> - Interface in com.ibm.streamsx.topology.tuple
A tuple that has a partition key.

L

LANGUAGE - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Language for the operator within its OpProperties.MODEL.
LANGUAGE_CPP - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
 
LANGUAGE_JAVA - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
 
LANGUAGE_PYTHON - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
 
LANGUAGE_SPL - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
 
last(long, TimeUnit) - Method in interface com.ibm.streamsx.topology.TStream
Declare a TWindow that continually represents the last time seconds of tuples (in the given time unit) on this stream.
last(int) - Method in interface com.ibm.streamsx.topology.TStream
Declare a TWindow that continually represents the last count tuples seen on this stream.
last() - Method in interface com.ibm.streamsx.topology.TStream
Declare a TWindow that continually represents the last tuple on this stream.
limitedSource(Supplier<T>, long) - Method in class com.ibm.streamsx.topology.Topology
Declare a limited source stream, where the number of tuples is limited to count.
limitedSourceN(Function<Long, T>, long) - Method in class com.ibm.streamsx.topology.Topology
Declare a limited source stream, where the number of tuples is limited to count.
Logic - Class in com.ibm.streamsx.topology.logic
 
Logic() - Constructor for class com.ibm.streamsx.topology.logic.Logic
 
longBeacon(TopologyElement) - Static method in class com.ibm.streamsx.topology.streams.BeaconStreams
Creates an infinite source stream of count tuples with no delay between each tuple.
longBeacon(TopologyElement, long) - Static method in class com.ibm.streamsx.topology.streams.BeaconStreams
Creates a source stream of count tuples with no delay between each tuple.
lowLatency() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Return a stream that is guaranteed to run in the same process as the calling TStream.
lowLatency() - Method in interface com.ibm.streamsx.topology.TStream
Return a stream that is guaranteed to run in the same process as the calling TStream.

M

main(String[]) - Static method in class com.ibm.streamsx.topology.context.remote.RemoteContextSubmit
 
main(String[]) - Static method in class com.ibm.streamsx.topology.context.StreamsContextSubmit
 
maxConsecutiveResetAttempts(int) - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Return a new configuration changing maxConsecutiveResetAttempts.
Message - Interface in com.ibm.streamsx.topology.tuple
An interface for tuple attributes common to messaging adapters in com.ibm.streamsx.topology.messaging.
MODEL - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Programming model used to create the operator.
MODEL_FUNCTIONAL - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
 
MODEL_SPL - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
 
modify(UnaryOperator<Tuple>) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Declare a new stream that modifies each tuple from this stream into one (or zero) tuple of the same type T.
modify(UnaryOperator<T>) - Method in interface com.ibm.streamsx.topology.TStream
Declare a new stream that modifies each tuple from this stream into one (or zero) tuple of the same type T.
MqttStreams - Class in com.ibm.streamsx.topology.messaging.mqtt
A simple connector to a MQTT broker for publishing TStream<Message> tuples to MQTT topics, and subscribing to MQTT topics and creating TStream<Message> streams.
MqttStreams(TopologyElement, Map<String, Object>) - Constructor for class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
Create a MQTT connector for publishing tuples to topics subscribing to topics.
multiTransform(Function<T, Iterable<U>>) - Method in interface com.ibm.streamsx.topology.TStream
Declare a new stream that transforms tuples from this stream into one or more (or zero) tuples of a different type U.

N

NAME - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
Name for a submitted application.
NAME_SUBMISSION_PARAM_NAMES - Static variable in interface com.ibm.streamsx.topology.generator.functional.FunctionalOpProperties
The name of the functional operator's actual SPL parameter for the submission parameters names
NAME_SUBMISSION_PARAM_VALUES - Static variable in interface com.ibm.streamsx.topology.generator.functional.FunctionalOpProperties
The name of the functional operator's actual SPL parameter for the submission parameters values
newTopology() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
notKeyed() - Static method in class com.ibm.streamsx.topology.logic.Logic
 
numbers(Number...) - Method in class com.ibm.streamsx.topology.Topology
Create a stream of Number tuples.

O

of(T) - Static method in class com.ibm.streamsx.topology.logic.Value
Return a constant value Supplier.
operator() - Method in interface com.ibm.streamsx.topology.context.Placeable
 
operator() - Method in interface com.ibm.streamsx.topology.TSink
Internal method.
operatorDriven() - Static method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Create a ConsistentRegionConfig.Trigger.OPERATOR_DRIVEN consistent region configuration.
OpProperties - Interface in com.ibm.streamsx.topology.generator.operator
 
output() - Method in interface com.ibm.streamsx.topology.TStream
Internal method.
OVERRIDE_RESOURCE_LOAD_PROTECTION - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
Optional override for a submitted application.

P

parallel(int) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Parallelizes the stream into a a fixed number of parallel channels using round-robin distribution.
parallel(Supplier<Integer>, TStream.Routing) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Parallelizes the stream into width parallel channels.
parallel(Supplier<Integer>, Function<Tuple, ?>) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Parallelizes the stream into a number of parallel channels using key based distribution.
parallel(int) - Method in interface com.ibm.streamsx.topology.TStream
Parallelizes the stream into a a fixed number of parallel channels using round-robin distribution.
parallel(Supplier<Integer>) - Method in interface com.ibm.streamsx.topology.TStream
Parallelizes the stream into width parallel channels.
parallel(Supplier<Integer>, TStream.Routing) - Method in interface com.ibm.streamsx.topology.TStream
Parallelizes the stream into width parallel channels.
parallel(Supplier<Integer>, Function<T, ?>) - Method in interface com.ibm.streamsx.topology.TStream
Parallelizes the stream into a number of parallel channels using key based distribution.
PAYLOAD - Static variable in class com.ibm.streamsx.topology.json.JSONStreams
JSON key for arrays and values.
periodic(int) - Static method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Create a ConsistentRegionConfig.Trigger.PERIODIC consistent region configuration.
periodicMultiSource(Supplier<Iterable<T>>, long, TimeUnit) - Method in class com.ibm.streamsx.topology.Topology
Declare a new source stream that calls data.get() periodically.
periodicSource(Supplier<T>, long, TimeUnit) - Method in class com.ibm.streamsx.topology.Topology
Declare a new source stream that calls data.get() periodically.
Placeable<T extends Placeable<T>> - Interface in com.ibm.streamsx.topology.context
Placement directives for a topology element when executing in a distributed runtime.
PLACEMENT - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Attribute for placement of the operator, a JSON object.
PLACEMENT_COLOCATE_KEY - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Attribute for derived colocation key.
PLACEMENT_EXPLICIT_COLOCATE_ID - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Attribute for an explicit colocation identifier.
PLACEMENT_ISOLATE_REGION_ID - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Attribute for isolation region identifier.
PLACEMENT_LOW_LATENCY_REGION_ID - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Attribute for low latency region identifier.
PLACEMENT_RESOURCE_TAGS - Static variable in interface com.ibm.streamsx.topology.generator.operator.OpProperties
Attribute for an resource tags, a list of tags.
POLICY_COUNT - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
POLICY_DELTA - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
POLICY_NONE - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
POLICY_PUNCTUATION - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
POLICY_TIME - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
Predicate<T> - Interface in com.ibm.streamsx.topology.function
A function that tests a tuple.
PRELOAD_APPLICATION_BUNDLES - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
Optionally specify whether to preload the job onto all resources in the instance.
print() - Method in interface com.ibm.streamsx.topology.TStream
Print each tuple on System.out.
process() - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
 
process(StreamingInput<Tuple>, Tuple) - Method in class com.ibm.streamsx.topology.file.TextFileReader
 
publish(TStream<? extends Message>) - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaProducer
Publish a stream of messages to one or more topics.
publish(TStream<? extends Message>, Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaProducer
Publish a stream of messages to a topic.
publish(TStream<? extends Message>) - Method in class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
Publish stream tuples to one or more MQTT topics.
publish(TStream<? extends Message>, Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
Publish stream tuples to one or more MQTT topics.
publish(String) - Method in interface com.ibm.streamsx.topology.TStream
Publish tuples from this stream for consumption by other IBM Streams applications.
publish(String, boolean) - Method in interface com.ibm.streamsx.topology.TStream
Publish tuples from this stream for consumption by other IBM Streams applications.

R

REMOTE_LOGGER - Static variable in interface com.ibm.streamsx.topology.context.remote.RemoteContext
Logger used for the Topology API, name com.ibm.streamsx.topology.
RemoteContext<T> - Interface in com.ibm.streamsx.topology.context.remote
 
RemoteContext.Type - Enum in com.ibm.streamsx.topology.context.remote
Types of the context that a JSON graph can be executed against.
RemoteContextFactory - Class in com.ibm.streamsx.topology.context.remote
 
RemoteContextFactory() - Constructor for class com.ibm.streamsx.topology.context.remote.RemoteContextFactory
 
RemoteContextSubmit - Class in com.ibm.streamsx.topology.context.remote
Given the path of a file containing the JSON representation of a graph, read the file and submit it to a remote context as JSON.
RemoteContextSubmit() - Constructor for class com.ibm.streamsx.topology.context.remote.RemoteContextSubmit
 
resetTimeout(long) - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
Return a new configuration changing resetTimeout.
RestServer - Class in com.ibm.streamsx.topology.inet
Adds a HTTP REST server to a topology to provide external interaction with the application.
RestServer(TopologyElement) - Constructor for class com.ibm.streamsx.topology.inet.RestServer
Create a REST server that will listen on port 8080.
RestServer(TopologyElement, int) - Constructor for class com.ibm.streamsx.topology.inet.RestServer
Create a REST server that will listen on the specified port.

S

sample(double) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Return a stream that is a random sample of this stream.
sample(double) - Method in interface com.ibm.streamsx.topology.TStream
Return a stream that is a random sample of this stream.
serialize(TStream<JSONObject>) - Static method in class com.ibm.streamsx.topology.json.JSONStreams
Create a stream of serialized JSON objects as String tuples.
SerializeJSON() - Constructor for class com.ibm.streamsx.topology.json.JSONStreams.SerializeJSON
 
SERVICE_NAME - Static variable in interface com.ibm.streamsx.topology.context.AnalyticsServiceProperties
Name of the service to use as a String.
setConsistent(ConsistentRegionConfig) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Set the source operator for this stream to be the start of a consistent region to support at least once and exactly once processing.
setConsistent(ConsistentRegionConfig) - Method in interface com.ibm.streamsx.topology.TStream
Set the source operator for this stream to be the start of a consistent region to support at least once and exactly once processing.
setDataDirectory(String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Set the data directory.
setDirectory(String) - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
 
setEncoding(String) - Method in class com.ibm.streamsx.topology.file.TextFileReader
 
setJobGroup(String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Set the job group.
setJobName(String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
Set the job name.
setOverrideResourceLoadProtection(Boolean) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
setPreloadApplicationBundles(Boolean) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
setTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
setTracing(Level) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
 
setValue(String) - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
setValue(Number) - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
SimpleMessage - Class in com.ibm.streamsx.topology.tuple
A Simple implementation of an immutable Message.
SimpleMessage(String) - Constructor for class com.ibm.streamsx.topology.tuple.SimpleMessage
Create a SimpleMessage that lacks a key and topic.
SimpleMessage(String, String) - Constructor for class com.ibm.streamsx.topology.tuple.SimpleMessage
Create a SimpleMessage that lacks a topic.
SimpleMessage(String, String, String) - Constructor for class com.ibm.streamsx.topology.tuple.SimpleMessage
Create a SimpleMessage.
single(TopologyElement) - Static method in class com.ibm.streamsx.topology.streams.BeaconStreams
Produce a source stream declaring a single tuple, with the value 0.
sink(Consumer<T>) - Method in interface com.ibm.streamsx.topology.TStream
Sink (terminate) this stream.
skipVersion(String, int...) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
Allow a test to be skipped for a specific version.
sortAndSubmit(List<File>) - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
 
source(Supplier<Iterable<T>>) - Method in class com.ibm.streamsx.topology.Topology
Declare a new source stream that iterates over the return of Iterable<T> get() from data.
SPL - Class in com.ibm.streamsx.topology.spl
Integration between Java topologies and SPL operator invocations.
SPL() - Constructor for class com.ibm.streamsx.topology.spl.SPL
 
splHandler(SPLStream, T) - Method in interface com.ibm.streamsx.topology.tester.Tester
Adds handler to capture the output of stream.
SPLInput - Interface in com.ibm.streamsx.topology.spl
Interface that can be connected to an SPL input port.
split(int, ToIntFunction<T>) - Method in interface com.ibm.streamsx.topology.TStream
Distribute a stream's tuples among n streams as specified by a splitter.
splOK() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
SPLSchemas - Interface in com.ibm.streamsx.topology.spl
Interchangeable SPL types.
SPLStream - Interface in com.ibm.streamsx.topology.spl
A SPLStream is a declaration of a continuous sequence of tuples with a defined SPL schema.
SPLStreams - Class in com.ibm.streamsx.topology.spl
Utilities for SPL attribute schema streams.
SPLStreams() - Constructor for class com.ibm.streamsx.topology.spl.SPLStreams
 
SPLWindow - Interface in com.ibm.streamsx.topology.spl
An SPL window, that has an SPL eviction policy and an SPL trigger policy.
startsWith(TStream<String>, String) - Static method in class com.ibm.streamsx.topology.streams.StringStreams
Create a filtered stream that contains String tuples starting with a specific term.
STREAMS_LOGGER - Static variable in class com.ibm.streamsx.topology.Topology
Logger used for the interactions with IBM Streams functionality, name com.ibm.streamsx.topology.streams.
StreamsContext<T> - Interface in com.ibm.streamsx.topology.context
A StreamsContext provides the ability to turn a Topology into an executable.
StreamsContext.Type - Enum in com.ibm.streamsx.topology.context
Types of the IBM Streams context that a Topology can be executed against.
StreamsContextFactory - Class in com.ibm.streamsx.topology.context
 
StreamsContextFactory() - Constructor for class com.ibm.streamsx.topology.context.StreamsContextFactory
 
StreamsContextSubmit - Class in com.ibm.streamsx.topology.context
Given the path of a file containing the JSON representation of a graph, read the file, generate the SPL, and write it to the specified file.
StreamsContextSubmit() - Constructor for class com.ibm.streamsx.topology.context.StreamsContextSubmit
 
STRING - Static variable in interface com.ibm.streamsx.topology.spl.SPLSchemas
SPL schema used by TStream<String> streams.
stringContents(TStream<String>, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
Return a condition that evaluates if stream has submitted at tuples matching values in the same order.
stringContentsUnordered(TStream<String>, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
Return a condition that evaluates if stream has submitted at tuples matching values in any order.
strings(String...) - Method in class com.ibm.streamsx.topology.Topology
Create a stream of String tuples.
StringStreams - Class in com.ibm.streamsx.topology.streams
Utilities for streams containing String tuples.
StringStreams() - Constructor for class com.ibm.streamsx.topology.streams.StringStreams
 
stringToSPLStream(TStream<String>) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Represent stream as an SPLStream with schema SPLSchemas.STRING.
stringTupleTester(TStream<String>, Predicate<String>) - Method in interface com.ibm.streamsx.topology.tester.Tester
 
SUBMISSION_DEPLOY - Static variable in interface com.ibm.streamsx.topology.context.remote.RemoteContext
 
SUBMISSION_DEPLOY - Static variable in interface com.ibm.streamsx.topology.context.StreamsContext
 
SUBMISSION_GRAPH - Static variable in interface com.ibm.streamsx.topology.context.remote.RemoteContext
 
SUBMISSION_GRAPH - Static variable in interface com.ibm.streamsx.topology.context.StreamsContext
 
SUBMISSION_PARAMS - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Submission parameters to be supplied to the topology when submitted for DISTRIBUTED, STANDALONE or ANALYTIC_SERVICE execution.
SUBMISSION_RESULTS - Static variable in interface com.ibm.streamsx.topology.context.remote.RemoteContext
 
SUBMISSION_RESULTS - Static variable in interface com.ibm.streamsx.topology.context.StreamsContext
 
SUBMISSION_RESULTS_FILE - Static variable in interface com.ibm.streamsx.topology.context.remote.RemoteContext
 
SUBMISSION_RESULTS_FILE - Static variable in interface com.ibm.streamsx.topology.context.StreamsContext
 
SubmissionParameter - Class in com.ibm.streamsx.topology.jobconfig
 
SubmissionParameter(String, boolean) - Constructor for class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
SubmissionParameter(String, String) - Constructor for class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
SubmissionParameter(String, Number) - Constructor for class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
 
submit(JsonObject) - Method in interface com.ibm.streamsx.topology.context.remote.RemoteContext
Submit a topology} to this Streams context as a JSON object.
submit(Topology) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
Submit topology to this Streams context.
submit(Topology, Map<String, Object>) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
Submit topology to this Streams context with a specific configuration.
submit(JSONObject) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
Submit a topology} to this Streams context as a JSON object.
subscribe(Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
Subscribe to a topic and create a stream of messages.
subscribe(Supplier<Integer>, Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
Subscribe to a topic and create a stream of messages.
subscribe(Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
Subscribe to a MQTT topic and create a stream of messages.
subscribe(TopologyElement, String, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Subscribe to an SPLStream published by topic.
subscribe(String, Class<T>) - Method in class com.ibm.streamsx.topology.Topology
Declare a stream that is a subscription to topic.
suffixFilter(TStream<String>, String...) - Static method in class com.ibm.streamsx.topology.file.FileStreams
Filter a Stream<String> containing file names by suffix values.
Supplier<T> - Interface in com.ibm.streamsx.topology.function
A function that supplies a value.

T

tagOpAsJavaPrimitive(BOperatorInvocation, String, String) - Static method in class com.ibm.streamsx.topology.spl.SPL
Internal method.
test(T) - Method in interface com.ibm.streamsx.topology.function.Predicate
Test tuple against this predicate.
Tester - Interface in com.ibm.streamsx.topology.tester
A Tester adds the ability to test a topology in a test framework such as JUnit.
TESTER_TYPE - Static variable in interface com.ibm.streamsx.topology.tester.junit.TestProperties
 
TestProperties - Interface in com.ibm.streamsx.topology.tester.junit
 
textFileReader(TStream<String>) - Static method in class com.ibm.streamsx.topology.file.FileStreams
Returns a Stream that reads each file named on its input stream, outputting a tuple for each line read.
TextFileReader - Class in com.ibm.streamsx.topology.file
 
TextFileReader() - Constructor for class com.ibm.streamsx.topology.file.TextFileReader
 
throttle(long, TimeUnit) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Throttle a stream by ensuring any tuple is submitted with least delay from the previous tuple.
throttle(long, TimeUnit) - Method in interface com.ibm.streamsx.topology.TStream
Throttle a stream by ensuring any tuple is submitted with least delay from the previous tuple.
ToIntFunction<T> - Interface in com.ibm.streamsx.topology.function
A function that applies a computation to a tuple and returns an int result.
toJSON(TStream<T>) - Static method in class com.ibm.streamsx.topology.json.JSONStreams
Declare a stream of JSON objects from a stream of Java objects that implement JSONAble.
ToJSON() - Constructor for class com.ibm.streamsx.topology.json.JSONStreams.ToJSON
 
toJSON() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Transform SPL tuples into JSON.
toJSON() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
Creates a JSON object with two attributes: sequence Value of BeaconTuple.getSequence() time Value of BeaconTuple.getTime()
toJSON() - Method in interface com.ibm.streamsx.topology.tuple.JSONAble
 
TOOLKIT_DIR - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Location of the generated toolkit root.
topology() - Method in class com.ibm.streamsx.topology.inet.RestServer
Get the topology for this REST server.
Topology - Class in com.ibm.streamsx.topology
A declaration of a topology of streaming data.
Topology() - Constructor for class com.ibm.streamsx.topology.Topology
Create an new topology with a default name.
Topology(String) - Constructor for class com.ibm.streamsx.topology.Topology
Create an new topology with a given name.
topology() - Method in class com.ibm.streamsx.topology.Topology
Return this topology.
topology() - Method in interface com.ibm.streamsx.topology.TopologyElement
The topology for this element.
TOPOLOGY_LOGGER - Static variable in class com.ibm.streamsx.topology.Topology
Logger used for the Topology API, name com.ibm.streamsx.topology.
TopologyElement - Interface in com.ibm.streamsx.topology
Any element in a Topology.
toSPL(TStream<JSONObject>) - Static method in class com.ibm.streamsx.topology.json.JSONStreams
Convert a JSON stream to an SPLStream.
toString(TStream<T>) - Static method in class com.ibm.streamsx.topology.streams.StringStreams
Create a stream that converts each input tuple to its String representation using toString().
toString() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
 
toString() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
 
toStringStream() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Create a TStream<Tuple> from this stream.
toStringStream(SPLStream) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Convert an SPLStream to a TStream<String> by taking its first attribute.
toStringStream(SPLStream, String) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Convert an SPLStream to a TStream<String> by taking a specific attribute.
toTupleString() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
Create a stream that converts each input tuple on this stream to its SPL character representation representation.
TRACING_LEVEL - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
transform(Function<T, U>) - Method in interface com.ibm.streamsx.topology.TStream
Declare a new stream that transforms each tuple from this stream into one (or zero) tuple of a different type U.
triggerCount(TWindow<Tuple, ?>, int) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Convert window to an SPL window with a count based trigger policy.
triggerTime(TWindow<Tuple, ?>, long, TimeUnit) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
Convert window to an SPL window with a time based trigger policy.
TSink - Interface in com.ibm.streamsx.topology
A handle to the sink of a TStream.
TStream<T> - Interface in com.ibm.streamsx.topology
A TStream is a declaration of a continuous sequence of tuples.
TStream.Routing - Enum in com.ibm.streamsx.topology
Enumeration for routing tuples to parallel channels.
tupleContents(SPLStream, Tuple...) - Method in interface com.ibm.streamsx.topology.tester.Tester
 
tupleCount(TStream<?>, long) - Method in interface com.ibm.streamsx.topology.tester.Tester
Return a condition that evaluates if stream has submitted exactly expectedCount number of tuples.
TWindow<T,K> - Interface in com.ibm.streamsx.topology
Declares a window of tuples for a TStream.
TYPE_NOT_WINDOWED - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
TYPE_SLIDING - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 
TYPE_TUMBLING - Static variable in interface com.ibm.streamsx.topology.generator.operator.WindowProperties
 

U

UnaryOperator<T> - Interface in com.ibm.streamsx.topology.function
Specialization of Function where the return type is the same as the argument type.
union(TStream<T>) - Method in interface com.ibm.streamsx.topology.TStream
Create a stream that is a union of this stream and other stream of the same type T.
union(Set<TStream<T>>) - Method in interface com.ibm.streamsx.topology.TStream
Create a stream that is a union of this stream and others streams of the same type T.
Util - Class in com.ibm.streamsx.topology.messaging.kafka
 

V

valid() - Method in interface com.ibm.streamsx.topology.tester.Condition
Test if this condition is valid.
Value<T> - Class in com.ibm.streamsx.topology.logic
A Supplier for a single constant T value.
Value(T) - Constructor for class com.ibm.streamsx.topology.logic.Value
Create a constant value Supplier.
valueOf(String) - Static method in enum com.ibm.streamsx.topology.consistent.ConsistentRegionConfig.Trigger
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.ibm.streamsx.topology.context.remote.RemoteContext.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.ibm.streamsx.topology.context.StreamsContext.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.ibm.streamsx.topology.spl.FileSPLStreams.Compression
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.ibm.streamsx.topology.TStream.Routing
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.ibm.streamsx.topology.consistent.ConsistentRegionConfig.Trigger
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.ibm.streamsx.topology.context.remote.RemoteContext.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.ibm.streamsx.topology.context.StreamsContext.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.ibm.streamsx.topology.spl.FileSPLStreams.Compression
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.ibm.streamsx.topology.TStream.Routing
Returns an array containing the constants of this enum type, in the order they are declared.
VCAP_SERVICES - Static variable in interface com.ibm.streamsx.topology.context.AnalyticsServiceProperties
Definition of IBM Bluemix services.
verifyComplete(Tester, Condition<?>, long, TimeUnit) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
verifyComplete(Tester, Condition<?>) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
 
viewer(TWindow<?, ?>, String, String) - Method in class com.ibm.streamsx.topology.inet.RestServer
Declare a HTTP REST view of tuples in a window.
VMARGS - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
Java virtual machine arguments.

W

window(TWindow<?, ?>) - Method in interface com.ibm.streamsx.topology.TStream
Declare a TWindow on this stream that has the same configuration as another window.
WindowProperties - Interface in com.ibm.streamsx.topology.generator.operator
 

X

XML - Static variable in interface com.ibm.streamsx.topology.spl.SPLSchemas
SPL schema used by TStream<com.ibm.streams.operator.types.XML> streams.
A B C D E F G H I J K L M N O P R S T U V W X 
streamsx.topology 1.5 @ IBMStreams GitHub