Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractTestClass - Class in com.teracloud.streams.topology.tester.junit
-
Test class providing utilities for testing of topologies.
- AbstractTestClass() - Constructor for class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- accept(File) - Method in class com.teracloud.streams.topology.file.DirectoryWatcher
- accept(T) - Method in interface com.teracloud.streams.topology.function.Consumer
- accept(T, int) - Method in interface com.teracloud.streams.topology.function.ObjIntConsumer
- ActiveVersion - Class in com.teracloud.streams.rest
-
Basic class to hold the ActiveVersion JSON structure
- ActiveVersion() - Constructor for class com.teracloud.streams.rest.ActiveVersion
- add(Tuple) - Method in class com.teracloud.streams.topology.tester.spl.ExpectedTuples
-
Add a tuple to expected list.
- addAsTuple(Object...) - Method in class com.teracloud.streams.topology.tester.spl.ExpectedTuples
-
Add a tuple to expected list.
- addClassDependency(Class<?>) - Method in class com.teracloud.streams.topology.Topology
-
Ensures that a class file is loaded into the application's runtime.
- addClassLibraries(String[]) - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Add class libraries to the functional class loader.
- addFileDependency(String, String) - Method in class com.teracloud.streams.topology.Topology
-
Add file or directory tree
location
to directorydstDirName
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.teracloud.streams.topology.Topology
-
Includes a jar file, specified by the
location
String, into the application runtime. - addJobControlPlane() - Method in class com.teracloud.streams.topology.Topology
-
Add job control plane to this topology.
- addResourceTags(String...) - Method in interface com.teracloud.streams.topology.context.Placeable
-
Add required resource tags for this topology element for distributed submission.
- addSubmissionParameter(String, boolean) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- addSubmissionParameter(String, Number) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- addSubmissionParameter(String, String) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- addToConfig(Map<String, Object>) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- addToolkit(TopologyElement, File) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Add a dependency on an SPL toolkit.
- addToolkitDependency(TopologyElement, String, String) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Add a logical dependency on an SPL toolkit.
- aggregate(Function<List<T>, A>) - Method in interface com.teracloud.streams.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.teracloud.streams.topology.TWindow
-
Declares a stream that containing tuples that represent an aggregation of this window.
- all(Condition<?>...) - Static method in interface com.teracloud.streams.topology.tester.Condition
-
Return a condition that is true if all conditions are valid.
- allowInsecureHosts(boolean) - Method in class com.teracloud.streams.rest.StreamsConnection
-
This function is used to disable checking the trusted certificate chain and should never be used in production environments
- and(Condition<?>...) - Method in interface com.teracloud.streams.topology.tester.Condition
-
Return a condition that is true if this AND all
conditions
are valid. - APP_DIR - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Location of the generated application directory when creating a Streams application bundle.
- ApplicationBundle - Class in com.teracloud.streams.rest
-
An object describing an Streams Domain
- ApplicationBundle() - Constructor for class com.teracloud.streams.rest.ApplicationBundle
- apply(C) - Method in class com.teracloud.streams.topology.streams.CollectionStreams.FlattenCollection
-
Just returns the collection,
TStream.multiTransform(Function)
will actually perform the flattening. - apply(JSONObject) - Method in class com.teracloud.streams.topology.json.JSONStreams.SerializeJSON
- apply(JSONAble) - Method in class com.teracloud.streams.topology.json.JSONStreams.ToJSON
- apply(Long) - Method in class com.teracloud.streams.topology.streams.BeaconStreams.BeaconFunction
- apply(String) - Method in class com.teracloud.streams.topology.json.JSONStreams.DeserializeJSON
- apply(M) - Method in class com.teracloud.streams.topology.streams.CollectionStreams.FlattenMap
- apply(T) - Method in interface com.teracloud.streams.topology.function.Function
- apply(T) - Method in class com.teracloud.streams.topology.logic.Identity
-
Returns the input value.
- apply(T1, T2) - Method in interface com.teracloud.streams.topology.function.BiFunction
- applyAsInt(T) - Method in interface com.teracloud.streams.topology.function.ToIntFunction
-
Apply the function to the
tuple
and return anint
. - assertTesterType() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- asType(Class<T>) - Method in interface com.teracloud.streams.topology.TStream
-
Return a strongly typed reference to this stream.
- atLeastTupleCount(TStream<?>, long) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Return a condition that evaluates if
stream
has submitted at leastexpectedCount
number of tuples. - autonomous() - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Return a stream matching this stream whose subsequent processing will execute in an autonomous region.
- autonomous() - Method in interface com.teracloud.streams.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.teracloud.streams.topology.streams.BeaconStreams
-
Creates an infinite source stream of tuples with no delay between each tuple.
- beacon(TopologyElement, long) - Static method in class com.teracloud.streams.topology.streams.BeaconStreams
-
Creates a source stream of
count
tuples with no delay between each tuple. - BeaconFunction() - Constructor for class com.teracloud.streams.topology.streams.BeaconStreams.BeaconFunction
- BeaconStreams - Class in com.teracloud.streams.topology.streams
-
Utilities for beacon streams.
- BeaconStreams() - Constructor for class com.teracloud.streams.topology.streams.BeaconStreams
- BeaconStreams.BeaconFunction - Class in com.teracloud.streams.topology.streams
- BeaconTuple - Class in com.teracloud.streams.topology.tuple
-
Tuple type issued by a beacon stream.
- BeaconTuple(long) - Constructor for class com.teracloud.streams.topology.tuple.BeaconTuple
-
Create a BeaconTuple with the current time.
- BeaconTuple(long, long) - Constructor for class com.teracloud.streams.topology.tuple.BeaconTuple
-
Create a BeaconTuple.
- BiFunction<T1,
T2, R> - Interface in com.teracloud.streams.topology.function -
A function that is passed two arguments and returns a value.
- BLOB - Static variable in interface com.teracloud.streams.topology.spl.SPLSchemas
-
SPL schema used by
TStream<com.ibm.streams.operator.types.Blob>
streams. - BROADCAST - Enum constant in enum class com.teracloud.streams.topology.TStream.Routing
-
Tuples are broadcast to all channels.
- builder() - Method in class com.teracloud.streams.topology.Topology
- builder() - Method in interface com.teracloud.streams.topology.TopologyElement
-
Get the underlying
OperatorGraph
. - BUNDLE - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Submission of the topology produces an Streams application bundle.
- bzip2 - Enum constant in enum class com.teracloud.streams.topology.spl.FileSPLStreams.Compression
C
- cancel() - Method in class com.teracloud.streams.rest.Job
-
Cancels this job.
- checkMaximumVersion(String, int...) - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
-
Only run a test at a specific maximum version or lower.
- checkMinimumVersion(String, int...) - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
-
Only run a test at a specific minimum version or higher.
- checkpointPeriod(long, TimeUnit) - Method in class com.teracloud.streams.topology.Topology
-
Checkpoint the state of the graph periodically.
- CollectionStreams - Class in com.teracloud.streams.topology.streams
-
Utilities for streams tuples that are collections of values.
- CollectionStreams() - Constructor for class com.teracloud.streams.topology.streams.CollectionStreams
- CollectionStreams.FlattenCollection<C extends Collection<T>,
T> - Class in com.teracloud.streams.topology.streams -
Function that flattens a collection when passed to
TStream.multiTransform(Function)
. - CollectionStreams.FlattenMap<M extends Map<K,
V>, K, V> - Class in com.teracloud.streams.topology.streams - colocate(Placeable<?>...) - Method in interface com.teracloud.streams.topology.context.Placeable
-
Colocate this element with other topology elements so that at runtime they all execute within the same processing element (PE or operating system process).
- colocate(Placeable<?>...) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Colocate this element with other topology elements so that at runtime they all execute within the same processing element (PE or operating system process).
- com.teracloud.streams.rest - package com.teracloud.streams.rest
-
Java bindings for the REST APIs of Streams.
- com.teracloud.streams.topology - package com.teracloud.streams.topology
-
Java application API for Streams.
- com.teracloud.streams.topology.consistent - package com.teracloud.streams.topology.consistent
-
At least once processing using consistent regions.
- com.teracloud.streams.topology.context - package com.teracloud.streams.topology.context
-
Context for executing Streams Java topologies.
- com.teracloud.streams.topology.file - package com.teracloud.streams.topology.file
-
File related streams.
- com.teracloud.streams.topology.function - package com.teracloud.streams.topology.function
-
Classes that provide the mechanisms to implement functional transformations on streams.
- com.teracloud.streams.topology.inet - package com.teracloud.streams.topology.inet
-
Network access to streaming data.
- com.teracloud.streams.topology.jobconfig - package com.teracloud.streams.topology.jobconfig
- com.teracloud.streams.topology.json - package com.teracloud.streams.topology.json
-
JSON streams.
- com.teracloud.streams.topology.logic - package com.teracloud.streams.topology.logic
-
Utilities and implementations of functional logic.
- com.teracloud.streams.topology.messaging.kafka - package com.teracloud.streams.topology.messaging.kafka
-
Support for integrating with the Apache Kafka messaging system http://kafka.apache.org.
- com.teracloud.streams.topology.messaging.mqtt - package com.teracloud.streams.topology.messaging.mqtt
-
Support for integrating with the MQTT messaging system http://mqtt.org.
- com.teracloud.streams.topology.spl - package com.teracloud.streams.topology.spl
-
Integration between Streams SPL and Java applications.
- com.teracloud.streams.topology.streams - package com.teracloud.streams.topology.streams
-
Utilities to create and transform streams.
- com.teracloud.streams.topology.tester - package com.teracloud.streams.topology.tester
-
Support for testing of topologies.
- com.teracloud.streams.topology.tester.junit - package com.teracloud.streams.topology.tester.junit
- com.teracloud.streams.topology.tester.spl - package com.teracloud.streams.topology.tester.spl
- com.teracloud.streams.topology.tuple - package com.teracloud.streams.topology.tuple
-
Interfaces for tuple types.
- compareTo(BeaconTuple) - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
- COMPILE_INSTALL_DIR - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Override Streams install directory for bundle compilation, defaults to $STREAMS_INSTALL.
- complete(StreamsContext<?>) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Submit the topology for this tester and wait for it to complete.
- complete(StreamsContext<?>, Condition<?>, long, TimeUnit) - Method in interface com.teracloud.streams.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.teracloud.streams.topology.tester.Tester
- complete(Tester, Condition<?>, long, TimeUnit) - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
-
Test a topology that may run forever.
- completeAndTestStringOutput(StreamsContext<?>, TStream<?>, long, TimeUnit, String...) - Method in interface com.teracloud.streams.topology.tester.Tester
- completeAndTestStringOutput(StreamsContext<?>, Map<String, Object>, TStream<?>, long, TimeUnit, String...) - Method in interface com.teracloud.streams.topology.tester.Tester
- Condition<T> - Interface in com.teracloud.streams.topology.tester
-
A test condition on a stream or application under test.
- CONFIG - Static variable in interface com.teracloud.streams.topology.context.JobProperties
-
Configuration for a submitted application.
- connectTo(BOperatorInvocation, boolean, BInputPort) - Method in interface com.teracloud.streams.topology.TStream
-
Internal method.
- ConsistentRegionConfig - Class in com.teracloud.streams.topology.consistent
-
Immutable consistent region configuration.
- ConsistentRegionConfig() - Constructor for class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Create a
ConsistentRegionConfig.Trigger.OPERATOR_DRIVEN
consistent region configuration. - ConsistentRegionConfig(int) - Constructor for class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Create a
ConsistentRegionConfig.Trigger.PERIODIC
consistent region configuration. - ConsistentRegionConfig.Trigger - Enum Class in com.teracloud.streams.topology.consistent
-
Defines how the drain-checkpoint cycle of a consistent region is triggered.
- constants(List<T>) - Method in class com.teracloud.streams.topology.Topology
-
Create a stream containing all the tuples in
data
. - Consumer<T> - Interface in com.teracloud.streams.topology.function
-
A function that takes an argument and returns nothing.
- contains(TStream<String>, String) - Static method in class com.teracloud.streams.topology.streams.StringStreams
-
Create a filtered stream that contains
String
tuples containing a specific term. - contents(SPLStream) - Method in class com.teracloud.streams.topology.tester.spl.ExpectedTuples
-
Create a condition for
stream
having the tuplesExpectedTuples.getTuples()
in the same order. - ContextProperties - Interface in com.teracloud.streams.topology.context
-
Properties that can be specified when submitting the topology to a context.
- convert(Function<Tuple, T>) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Convert SPL tuples into Java objects.
- convertStream(TStream<T>, BiFunction<T, OutputTuple, OutputTuple>, StreamSchema) - Static method in class com.teracloud.streams.topology.spl.SPLStreams
-
Convert a
Stream
to anSPLStream
. - create(int, String) - Static method in exception com.teracloud.streams.rest.RESTException
-
Customized exception that can provide more information on REST errors
- createCustomMetric(String, String, String, LongSupplier) - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Create a custom metric.
- createInstance(String, String, String) - Static method in class com.teracloud.streams.rest.StreamsConnection
-
Create a connection to Streams REST API.
- createNullValue() - Static method in class com.teracloud.streams.topology.spl.SPL
-
Create an SPL value wrapper object for an SPL null value.
- createSubmissionParameter(Topology, String, Object, boolean) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Create a submission parameter with or without a default value.
- createSubmissionParameter(String, Class<T>) - Method in class com.teracloud.streams.topology.Topology
-
Create a submission parameter without a default value.
- createSubmissionParameter(String, T) - Method in class com.teracloud.streams.topology.Topology
-
Create a submission parameter with a default value.
- createValue(T, Type.MetaType) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Create an SPL value wrapper object for the specified SPL
MetaType
. - csvCompressedReader(TStream<String>, StreamSchema, FileSPLStreams.Compression) - Static method in class com.teracloud.streams.topology.spl.FileSPLStreams
-
Create an
SPLStream
using thespl.adapter::FileSource
operator that reads CSV records from compressed files with names delivered byfileNames
. - csvReader(TStream<String>, StreamSchema) - Static method in class com.teracloud.streams.topology.spl.FileSPLStreams
-
Create an
SPLStream
using thespl.adapter::FileSource
operator that reads CSV records from files with names delivered byfileNames
.
D
- DATA_DIRECTORY - Static variable in interface com.teracloud.streams.topology.context.JobProperties
-
Location of the submitted application's data directory.
- deserialize(TStream<String>) - Static method in class com.teracloud.streams.topology.json.JSONStreams
-
Declare a stream of JSON objects from a stream of serialized JSON tuples.
- DeserializeJSON() - Constructor for class com.teracloud.streams.topology.json.JSONStreams.DeserializeJSON
- directoryWatcher(TopologyElement, String) - Static method in class com.teracloud.streams.topology.file.FileStreams
-
Creates a stream of absolute newly created file names from watching
directory
. - DirectoryWatcher - Class in com.teracloud.streams.topology.file
- DirectoryWatcher() - Constructor for class com.teracloud.streams.topology.file.DirectoryWatcher
- DISTRIBUTED - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
The topology is submitted to an Streams instance.
- DISTRIBUTED_TESTER - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Testing variant of
StreamsContext.Type.DISTRIBUTED_TESTER
. - Domain - Class in com.teracloud.streams.rest
-
An object describing an Streams Domain
- Domain() - Constructor for class com.teracloud.streams.rest.Domain
- drainTimeout(long) - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Return a new configuration changing
drainTimeout
.
E
- Element - Class in com.teracloud.streams.rest
-
Streams element.
- Element() - Constructor for class com.teracloud.streams.rest.Element
- EMBEDDED - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Topology is executed within the Java virtual machine that declared it.
- EMBEDDED_TESTER - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Testing variant of
StreamsContext.Type.EMBEDDED
. - endlessSource(Supplier<T>) - Method in class com.teracloud.streams.topology.Topology
-
Declare an endless source stream.
- endlessSourceN(Function<Long, T>) - Method in class com.teracloud.streams.topology.Topology
-
Declare an endless source stream.
- endLowLatency() - Method in interface com.teracloud.streams.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.teracloud.streams.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.teracloud.streams.topology.spl.SPLStream
-
Ends a parallel region by merging the channels into a single stream.
- endParallel() - Method in interface com.teracloud.streams.topology.TStream
-
Ends a parallel region by merging the channels into a single stream.
- equals(Object) - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
- equals(Object) - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
- equals(Object) - Method in class com.teracloud.streams.topology.tuple.SimpleMessage
- ExpectedTuples - Class in com.teracloud.streams.topology.tester.spl
-
List of expected tuples.
- ExpectedTuples(StreamSchema) - Constructor for class com.teracloud.streams.topology.tester.spl.ExpectedTuples
-
Create an initially empty ExpectedTuples.
F
- failed() - Method in interface com.teracloud.streams.topology.tester.Condition
-
Has the condition failed.
- FileSPLStreams - Class in com.teracloud.streams.topology.spl
-
Creation of SPLStreams that relate to files.
- FileSPLStreams() - Constructor for class com.teracloud.streams.topology.spl.FileSPLStreams
- FileSPLStreams.Compression - Enum Class in com.teracloud.streams.topology.spl
- FileStreams - Class in com.teracloud.streams.topology.file
-
Utilities for file system related streams.
- FileStreams() - Constructor for class com.teracloud.streams.topology.file.FileStreams
- filter(Predicate<Tuple>) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Declare a new stream that filters tuples from this stream.
- filter(Predicate<T>) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a new stream that filters tuples from this stream.
- finalizeGraph(StreamsContext<?>) - Method in class com.teracloud.streams.topology.Topology
-
Resolves the jar dependencies, sets the respective parameters.
- first(BiFunction<T, U, R>) - Static method in class com.teracloud.streams.topology.logic.Logic
-
Wrap a
BiFunction
instance that operators on a single value for the second parameter (typeU
) as aBiFunction
that takes anList
. - flatMap(Function<T, Iterable<U>>) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a new stream that maps tuples from this stream into one or more (or zero) tuples of a different type
U
. - flatten(TStream<C>) - Static method in class com.teracloud.streams.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.teracloud.streams.topology.json.JSONStreams
-
Declare a stream that flattens an array present in the input tuple.
- FlattenCollection() - Constructor for class com.teracloud.streams.topology.streams.CollectionStreams.FlattenCollection
- flattenMap(TStream<M>) - Static method in class com.teracloud.streams.topology.streams.CollectionStreams
- FlattenMap() - Constructor for class com.teracloud.streams.topology.streams.CollectionStreams.FlattenMap
- forEach(Consumer<T>) - Method in interface com.teracloud.streams.topology.TStream
-
Sink (terminate) this stream.
- fromProperties(Map<String, ? extends Object>) - Static method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Create a
JobConfig
from a configuration map. - Function<T,
R> - Interface in com.teracloud.streams.topology.function -
A function that is passed an argument and returns a value.
- FunctionContainer - Interface in com.teracloud.streams.topology.function
-
Container for a function executing in a Streams application.
- FunctionContext - Interface in com.teracloud.streams.topology.function
-
Context for a function executing in a Streams application.
G
- get() - Method in interface com.teracloud.streams.topology.function.Supplier
- get() - Method in class com.teracloud.streams.topology.logic.Value
-
Return the constant value.
- getActiveVersion() - Method in class com.teracloud.streams.rest.Instance
-
Gets information about the Streams Installation that was used to start this instance
- getApplicationConfiguration(String) - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Get the application configuration specified by name.
- getApplicationConsoleURL() - Method in class com.teracloud.streams.rest.Instance
-
Streams application console URL.
- getApplicationName() - Method in class com.teracloud.streams.rest.Job
-
Gets the name of the streams processing application that this job is running
- getArchitecture() - Method in class com.teracloud.streams.rest.ActiveVersion
- getAsJson() - Method in class com.teracloud.streams.rest.RESTErrorMessage
-
Gets the json object of this error message
- getAuthenticator() - Method in class com.teracloud.streams.rest.StreamsConnection
- getBuildVersion() - Method in class com.teracloud.streams.rest.ActiveVersion
- getChannel() - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Get the index of the parallel channel the function is on.
- getComposite() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- getConfig() - Method in class com.teracloud.streams.topology.messaging.kafka.KafkaConsumer
-
Get the connector's
KafkaConsumer
configuration information. - getConfig() - Method in class com.teracloud.streams.topology.messaging.kafka.KafkaProducer
-
Get the connector's
KafkaProducer
configuration information. - getConfig() - Method in class com.teracloud.streams.topology.messaging.mqtt.MqttStreams
-
Get the connector's configuration information.
- getConfig() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- getConfig() - Method in class com.teracloud.streams.topology.Topology
- getConfiguredHost() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Get the host this container is executing on.
- getContainer() - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Get the container hosting a function
- getCreationTime() - Method in class com.teracloud.streams.rest.Domain
-
Gets the time in milliseconds when this domain was created.
- getCreationTime() - Method in class com.teracloud.streams.rest.Instance
-
Gets the time in milliseconds when this instance was created
- getCreationUser() - Method in class com.teracloud.streams.rest.Domain
-
Gets the user ID that created this instance.
- getCreationUser() - Method in class com.teracloud.streams.rest.Instance
-
Gets the user ID that created this instance
- getCurrentWorkingPath() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the current working path of the processing element
- getCustomMetricNames() - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Get the set of custom metric names created in this context.
- getDataDirectory() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Get the data directory.
- getDefaultDomainId() - Static method in class com.teracloud.streams.topology.context.StreamsContextFactory
-
Get the default Streams domain identifier.
- getDefaultInstanceId() - Static method in class com.teracloud.streams.topology.context.StreamsContextFactory
-
Get the default Streams instance identifier.
- getDefaultStreamsInstall() - Static method in class com.teracloud.streams.topology.context.StreamsContextFactory
-
Get the default Streams install location.
- getDefaultTesterType() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- getDefaultTimeout() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- getDefaultValue() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- getDependencyResolver() - Method in class com.teracloud.streams.topology.Topology
-
Internal use only.
- getDescription() - Method in class com.teracloud.streams.rest.Metric
-
Gets the description for this metric
- getDirectory() - Method in class com.teracloud.streams.topology.file.DirectoryWatcher
- getDisplayName() - Method in class com.teracloud.streams.rest.Resource
-
Get the display name for this resource.
- getDomain() - Method in class com.teracloud.streams.rest.Instance
-
Get the Streams domain for this instance.
- getDomainId() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Return the Streams domain identifier for this container.
- getDrainTimeout() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Get the drain timeout for this configuration.
- getEditionName() - Method in class com.teracloud.streams.rest.ActiveVersion
- getElement() - Method in interface com.teracloud.streams.rest.Result
-
Get the element associated with the request.
- getEmbedded() - Static method in class com.teracloud.streams.topology.context.StreamsContextFactory
-
Get an
EMBEDDED context
. - getEncoding() - Method in class com.teracloud.streams.topology.file.TextFileReader
- getFullProductVersion() - Method in class com.teracloud.streams.rest.ActiveVersion
- getHealth() - Method in class com.teracloud.streams.rest.Instance
-
Gets the summarized status of jobs in this instance
- getHealth() - Method in class com.teracloud.streams.rest.Job
-
Gets the health indicator for this job
- getHealth() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the health indicator for this processing element
- getId() - Method in class com.teracloud.streams.rest.Domain
-
Gets the Streams unique identifier for this domain.
- getId() - Method in class com.teracloud.streams.rest.Instance
-
Gets the Streams unique identifier for this instance
- getId() - Method in class com.teracloud.streams.rest.Job
-
Gets the id of this job
- getId() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the id of this processing element
- getId() - Method in class com.teracloud.streams.rest.Resource
-
Get the unique Streams identifier for this resource.
- getId() - Method in interface com.teracloud.streams.rest.Result
-
Get the object identifier associated with the request.
- getId() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Get the runtime identifier for this container.
- getIndexWithinJob() - Method in class com.teracloud.streams.rest.Operator
-
Gets the index of this operator within the
Job
- getIndexWithinJob() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the index of this processing element within the
Job
- getIndexWithinOperator() - Method in class com.teracloud.streams.rest.InputPort
-
Gets the index of this input port within the
Operator
- getIndexWithinOperator() - Method in class com.teracloud.streams.rest.OutputPort
-
Gets the index of this output port within the
operator
- getIndexWithinPE() - Method in class com.teracloud.streams.rest.PEInputPort
-
Gets the index of this input port within the
processing element
- getIndexWithinPE() - Method in class com.teracloud.streams.rest.PEOutputPort
-
Gets the index of this output port within the
processing element
- getInputPorts() - Method in class com.teracloud.streams.rest.Operator
-
Gets a list of
input ports
for this operator - getInputPorts() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets a list of
processing element input ports
for this processing element - getInstance() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Obtain the
Instance
this resource is allocated to. - getInstance(String) - Method in class com.teracloud.streams.rest.StreamsConnection
-
Gets a specific
instance
identified by the instanceId at this Streams connection - getInstanceId() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Return the Streams instance identifier for this container.
- getInstances() - Method in class com.teracloud.streams.rest.StreamsConnection
-
Gets a list of
instances
that are available to this IBM Streams connection - getInvocationName() - Method in interface com.teracloud.streams.topology.context.Placeable
-
Return the invocation name of this element.
- getIpAddress() - Method in class com.teracloud.streams.rest.Resource
-
Get the IP address for this resource.
- getJob(String) - Method in class com.teracloud.streams.rest.Instance
-
Gets the
Job
for a given jobId in this instance - getJobGroup() - Method in class com.teracloud.streams.rest.Job
-
Gets the group this job belongs to
- getJobGroup() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Get the job group.
- getJobId() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Get the runtime identifier for this container's running job.
- getJobName() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Return the name of this job.
- getJobName() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Get the job name.
- getJobs() - Method in class com.teracloud.streams.rest.Instance
-
Gets a list of
jobs
that this instance knows about - getJobs() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Gets a list of jobs running on this resource in this instance.
- getJSON(TopologyElement, String, long, TimeUnit) - Static method in class com.teracloud.streams.topology.inet.HTTPStreams
-
Periodically poll a web service using HTTP
GET
forapplication/json
data. - getKey() - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
-
Get the key (sequence identifier) of this tuple.
- getKey() - Method in interface com.teracloud.streams.topology.tuple.Keyable
-
Returns the partition key for this tuple.
- getKey() - Method in interface com.teracloud.streams.topology.tuple.Message
-
Get the message key for this object.
- getKey() - Method in class com.teracloud.streams.topology.tuple.SimpleMessage
- getLastTimeRetrieved() - Method in class com.teracloud.streams.rest.Metric
-
Gets the Epoch time when the metric was most recently retrieved
- getLaunchCount() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the number of times this processing element was started manually or automatically because of failures
- getLogicalName() - Method in class com.teracloud.streams.rest.Operator
-
The logical name of this operator.
- getMaxChannels() - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Get the total number of parallel channels for the parallel region that the function is in.
- getMaxConsecutiveResetAttempts() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Get the maximum number of consecutive reset attempts.
- getMessage() - Method in class com.teracloud.streams.rest.RESTErrorMessage
-
Gets the error message
- getMessage() - Method in interface com.teracloud.streams.topology.tuple.Message
-
Get the message content for this object.
- getMessage() - Method in class com.teracloud.streams.topology.tuple.SimpleMessage
- getMessageId() - Method in class com.teracloud.streams.rest.RESTErrorMessage
-
Gets the id of this error message
- getMetricKind() - Method in class com.teracloud.streams.rest.Metric
-
Describes the kind of metric that has been retrieved
- getMetrics() - Method in class com.teracloud.streams.rest.InputPort
-
Gets the
metrics
for this input port - getMetrics() - Method in class com.teracloud.streams.rest.Operator
-
Gets a list of
metrics
for this operator - getMetrics() - Method in class com.teracloud.streams.rest.OutputPort
-
Gets the
metrics
for this output port - getMetrics() - Method in class com.teracloud.streams.rest.PEInputPort
-
Gets the
metrics
for this processing element input port - getMetrics() - Method in class com.teracloud.streams.rest.PEOutputPort
-
Gets the
metrics
for this output port - getMetrics() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets a list of
metrics
for this processing element - getMetrics() - Method in class com.teracloud.streams.rest.Resource
-
Gets the
metrics
for this resource. - getMetricType() - Method in class com.teracloud.streams.rest.Metric
-
Describes the type of metric that has been retrieved
- getMinimumOSBaseVersion() - Method in class com.teracloud.streams.rest.ActiveVersion
- getMinimumOSPatchVersion() - Method in class com.teracloud.streams.rest.ActiveVersion
- getMinimumOSVersion() - Method in class com.teracloud.streams.rest.ActiveVersion
- getName() - Method in class com.teracloud.streams.rest.InputPort
-
Gets the name for this input port
- getName() - Method in class com.teracloud.streams.rest.Job
-
Gets the name of this job
- getName() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- getName() - Method in class com.teracloud.streams.rest.Metric
-
Gets the name of this metric
- getName() - Method in class com.teracloud.streams.rest.Operator
-
Name of this operator
- getName() - Method in class com.teracloud.streams.rest.OutputPort
-
Gets the name for this output port
- getName() - Method in class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- getName() - Method in class com.teracloud.streams.topology.Topology
-
Name of this topology.
- getNamespace() - Method in class com.teracloud.streams.topology.Topology
-
Namespace of this topology.
- getOperatorKind() - Method in class com.teracloud.streams.rest.Operator
-
SPL primitive operator type for this operator
- getOperators() - Method in class com.teracloud.streams.rest.Job
-
Gets a list of
operators
for this job - getOperators() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets a list of
operators
for this processing element - getOptionalConnections() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the status of optional connections for this processing element.
- getOsCapabilities() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets a list of the operating system capabilities
- getOutputPorts() - Method in class com.teracloud.streams.rest.Operator
-
Gets a list of
output ports
for this operator - getOutputPorts() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets a list of
processing element output ports
for this processing element - getOverrideResourceLoadProtection() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- getOwner() - Method in class com.teracloud.streams.rest.Instance
-
Gets the user ID that represents the owner of this instance
- getParameterKind() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- getPE() - Method in class com.teracloud.streams.rest.Operator
-
Get the PE for this operator.
- getPendingTracingLevel() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Describes a pending change to the granularity of the trace information that is stored for this processing element.
- getPeriod() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Get the trigger period.
- getPes() - Method in class com.teracloud.streams.rest.Instance
-
Gets a list of
processing elements
for this instance. - getPes() - Method in class com.teracloud.streams.rest.Job
-
Gets a list of
processing elements
for this job - getPes() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Gets a list of processing elements running on this resource in this instance.
- getPreloadApplicationBundles() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- getProcessId() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the operating system process ID for this processing element
- getProductName() - Method in class com.teracloud.streams.rest.ActiveVersion
- getProductVersion() - Method in class com.teracloud.streams.rest.ActiveVersion
- getProductVersion() - Method in class com.teracloud.streams.rest.Instance
-
Gets the product version, please note that this is null for Streams version < 5.2
- getRawResult() - Method in interface com.teracloud.streams.rest.Result
-
Get the raw result from the request.
- getRelaunchCount() - Method in interface com.teracloud.streams.topology.function.FunctionContainer
-
Return the number of times this container has been relaunched.
- getRelocatable() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Indicates whether or not this processing element can be relocated to a different resource
- getRequiredConnections() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Status of the required connections for this processing element.
- getResetTimeout() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Get the reset timeout for this configuration.
- getResource() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Obtain the
Resource
object for detailed information on the resource. - getResourceAllocation() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the
resource allocation
for this processing element. - getResourceAllocations() - Method in class com.teracloud.streams.rest.Instance
-
Gets a list of
resource allocations
for this instance. - getResourceAllocations() - Method in class com.teracloud.streams.rest.Job
-
Gets a list of
resource allocations
for this job. - getResourceTags() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets a list of resource tags for this processing element
- getResourceTags() - Method in interface com.teracloud.streams.topology.context.Placeable
-
Get the set of resource tags this element requires.
- getResourceType() - Method in class com.teracloud.streams.rest.InputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.Instance
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.Job
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.Metric
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.Operator
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.OutputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.PEInputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.PEOutputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.Resource
-
Identifies the REST resource type
- getResourceType() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Identifies the REST resource type
- getRestartable() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Indicates whether or not this processing element can be restarted
- getResult() - Method in interface com.teracloud.streams.topology.tester.Condition
-
Deprecated.
- getScheduledExecutorService() - Method in interface com.teracloud.streams.topology.function.FunctionContext
-
Return a scheduler to execute background tasks.
- getSchedulerStatus() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Status of the resource.
- getSchema() - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
SPL schema of this stream.
- getSchema() - Method in class com.teracloud.streams.topology.tester.spl.ExpectedTuples
-
Get the schema of the tuples.
- getSequence() - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
-
Get the sequence identifier of this tuple.
- getStartedBy() - Method in class com.teracloud.streams.rest.Job
-
Identifies the user ID that started this job
- getStartTime() - Method in class com.teracloud.streams.rest.Instance
-
Gets the time in milliseconds when the instance was started.
- getStatus() - Method in class com.teracloud.streams.rest.Domain
-
Gets the status of the domain.
- getStatus() - Method in class com.teracloud.streams.rest.Instance
-
Gets the status of the instance
- getStatus() - Method in class com.teracloud.streams.rest.Job
-
Describes the status of this job
- getStatus() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the status of this processing element
- getStatus() - Method in class com.teracloud.streams.rest.Resource
-
Status of the resource.
- getStatus() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Scheduler status of the resource.
- getStatusCode() - Method in exception com.teracloud.streams.rest.RESTException
-
Gets the error status code for this exception
- getStatusReason() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets additional status for this processing element
- getStream() - Method in interface com.teracloud.streams.topology.spl.SPLInput
- getStream() - Method in interface com.teracloud.streams.topology.spl.SPLWindow
-
SPL stream for this window.
- getStream() - Method in interface com.teracloud.streams.topology.TWindow
-
Get this window's stream.
- getStreamName() - Method in class com.teracloud.streams.rest.OutputPort
-
Identifies the name of the output stream associated with this output port
- getStreamsConnection() - Method in class com.teracloud.streams.rest.Element
- getStreamsContext(StreamsContext.Type) - Static method in class com.teracloud.streams.topology.context.StreamsContextFactory
-
Get a
StreamsContext
from its type. - getStreamsContext(String) - Static method in class com.teracloud.streams.topology.context.StreamsContextFactory
-
Get a
StreamsContext
from its type name. - getStreamsErrorMessageAsJson() - Method in exception com.teracloud.streams.rest.RESTException
-
Gets the Streams message for this exception as a Json Object
- getStreamsErrorMessageId() - Method in exception com.teracloud.streams.rest.RESTException
-
Gets the Streams message ID for this exception
- getStreamsTracing() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- getSubmissionParameters() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Get the submission parameters.
- getSubmitParameters() - Method in class com.teracloud.streams.rest.Job
-
Gets the list of
parameters
that were submitted to this job - getSubmitTime() - Method in class com.teracloud.streams.rest.Job
-
Gets the Epoch time when this job was submitted
- getTester() - Method in class com.teracloud.streams.topology.Topology
-
Get the tester for this topology.
- getTesterContext() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
-
Return the default context for tests.
- getTesterType() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- getThreadFactory() - Method in interface com.teracloud.streams.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.teracloud.streams.topology.tuple.BeaconTuple
-
Get the time of this tuple.
- getTimeUnit() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Get the time unit for
ConsistentRegionConfig.getPeriod()
,ConsistentRegionConfig.getDrainTimeout()
and {@link #getResetTimeout()()}. - getTopic() - Method in interface com.teracloud.streams.topology.tuple.Message
-
Get the message topic for this object.
- getTopic() - Method in class com.teracloud.streams.topology.tuple.SimpleMessage
- getTopology() - Method in interface com.teracloud.streams.topology.tester.Tester
-
Get the topology for this tester.
- getTracing() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- getTracingLevel() - Method in class com.teracloud.streams.rest.ProcessingElement
-
Gets the granularity of the tracing level for this processing element
- getTransportType() - Method in class com.teracloud.streams.rest.PEInputPort
-
Gets the transport type for this processing element input port
- getTransportType() - Method in class com.teracloud.streams.rest.PEOutputPort
-
Gets the transport type for this processing element output port
- getTrigger() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Get the trigger type.
- getTupleClass() - Method in interface com.teracloud.streams.topology.TStream
-
Class of the tuples on this stream, if known.
- getTupleClass() - Method in interface com.teracloud.streams.topology.TWindow
-
Class of the tuples in this window.
- getTuples() - Method in class com.teracloud.streams.topology.tester.spl.ExpectedTuples
-
Get the expected tuples.
- getTupleType() - Method in interface com.teracloud.streams.topology.TStream
-
Type of the tuples on this stream.
- getTupleType() - Method in interface com.teracloud.streams.topology.TWindow
-
Type of the tuples in this window.
- getType() - Method in interface com.teracloud.streams.topology.context.StreamsContext
-
The type of this context.
- getValue() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- getValue() - Method in class com.teracloud.streams.rest.Metric
-
Gets the value for this metric
- getValue() - Method in class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- getValues() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- getZooKeeperConnectionString() - Method in class com.teracloud.streams.rest.Domain
-
Gets the ZooKeeper connection string for this domain.
- GROUP - Static variable in interface com.teracloud.streams.topology.context.JobProperties
-
Group name for a submitted application.
- gzip - Enum constant in enum class com.teracloud.streams.topology.spl.FileSPLStreams.Compression
H
- HASH_PARTITIONED - Enum constant in enum class com.teracloud.streams.topology.TStream.Routing
-
Tuples will be consistently routed to the same channel based upon their
hashCode()
. - hashCode() - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
- hashCode() - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
- hashCode() - Method in class com.teracloud.streams.topology.tuple.SimpleMessage
- hasSubmissionParameters() - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Have any submission parameters been added.
- hasTester() - Method in class com.teracloud.streams.topology.Topology
-
Has the tester been created for this topology.
- HTTPStreams - Class in com.teracloud.streams.topology.inet
-
Access to data in web servers or services using HTTP.
- HTTPStreams() - Constructor for class com.teracloud.streams.topology.inet.HTTPStreams
I
- identifyStreamsxMessagingVer() - Static method in class com.teracloud.streams.topology.messaging.kafka.Util
- identity() - Static method in class com.teracloud.streams.topology.logic.Logic
- Identity<T> - Class in com.teracloud.streams.topology.logic
-
Identity unary function that returns its input.
- Identity() - Constructor for class com.teracloud.streams.topology.logic.Identity
- Initializable - Interface in com.teracloud.streams.topology.function
-
Optional interface that a function can implement to perform initialization.
- initialize(OperatorContext) - Method in class com.teracloud.streams.topology.file.DirectoryWatcher
- initialize(OperatorContext) - Method in class com.teracloud.streams.topology.file.TextFileReader
- initialize(FunctionContext) - Method in interface com.teracloud.streams.topology.function.Initializable
-
Initialize this function.
- InputPort - Class in com.teracloud.streams.rest
-
An Input Port of the Streams Operator
- InputPort() - Constructor for class com.teracloud.streams.rest.InputPort
- Instance - Class in com.teracloud.streams.rest
-
An object describing an Streams Instance
- Instance() - Constructor for class com.teracloud.streams.rest.Instance
- invocationName(String) - Method in interface com.teracloud.streams.topology.context.Placeable
-
Set the invocation name of this placeable.
- invocationName(String) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Set the invocation name of this placeable.
- invokeJavaPrimitive(TopologyElement, Class<? extends Operator>, List<? extends SPLInput>, List<StreamSchema>, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.topology.spl.JavaPrimitive
-
Invoke an SPL Java primitive operator with an arbitrary number of input and output ports.
- invokeJavaPrimitive(Class<? extends Operator>, SPLInput, StreamSchema, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.topology.spl.JavaPrimitive
-
Create an SPLStream from the invocation of an SPL Java primitive operator with a single input port & output port.
- invokeJavaPrimitiveSink(Class<? extends Operator>, SPLInput, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.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.teracloud.streams.topology.spl.JavaPrimitive
-
Invocation of a Java primitive source operator to produce a SPL Stream.
- invokeOperator(TopologyElement, String, String, List<? extends SPLInput>, List<StreamSchema>, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Invoke an SPL operator with an arbitrary number of input and output ports.
- invokeOperator(String, SPLInput, StreamSchema, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.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.teracloud.streams.topology.spl.SPL
-
Create an SPLStream from the invocation of an SPL operator that consumes a stream and produces a stream.
- invokeSink(String, SPLInput, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Invocation an SPL operator that consumes a Stream.
- invokeSink(String, String, SPLInput, Map<String, ? extends Object>) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Invocation an SPL operator that consumes a Stream.
- invokeSource(TopologyElement, String, Map<String, Object>, StreamSchema) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Invocation an SPL source operator to produce a Stream.
- isApplicationResource() - Method in class com.teracloud.streams.rest.ResourceAllocation
-
Indicates whether the resource is an application resource.
- isKeyed() - Method in interface com.teracloud.streams.topology.TWindow
-
Is the window keyed.
- isOk() - Method in interface com.teracloud.streams.rest.Result
-
Was the request successful.
- isolate() - Method in interface com.teracloud.streams.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.teracloud.streams.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.teracloud.streams.topology.context.Placeable
-
Can this element have placement directives applied to it.
- isProductVersionAtLeast(int, int) - Method in class com.teracloud.streams.rest.Instance
-
Tests if the instance has a minimum major.minor product version.
- isRequired() - Method in class com.teracloud.streams.rest.JobSubmitParameters
- isSupported(Topology) - Method in interface com.teracloud.streams.topology.context.StreamsContext
-
Answers if this StreamsContext supports execution of the
topology
. - isVerify() - Method in class com.teracloud.streams.rest.StreamsConnection
J
- JavaPrimitive - Class in com.teracloud.streams.topology.spl
-
Integration between Java topologies and SPL Java primitive operators.
- JavaPrimitive() - Constructor for class com.teracloud.streams.topology.spl.JavaPrimitive
- Job - Class in com.teracloud.streams.rest
-
An object describing an Streams Job submitted within a specified instance
- Job() - Constructor for class com.teracloud.streams.rest.Job
- JOB_SUBMISSION - Static variable in interface com.teracloud.streams.topology.context.ResultProperties
-
Result of a successful job submission as a JSON object.
- JobConfig - Class in com.teracloud.streams.topology.jobconfig
-
A job configuration.
- JobConfig() - Constructor for class com.teracloud.streams.topology.jobconfig.JobConfig
-
An empty job configuration.
- JobConfig(String, String) - Constructor for class com.teracloud.streams.topology.jobconfig.JobConfig
-
Job configuration with a job name and group.
- JobProperties - Interface in com.teracloud.streams.topology.context
-
Job properties specific to distributed contexts.
- JobSubmitParameters - Class in com.teracloud.streams.rest
-
Holds Submisson Paramters for a Job
- JobSubmitParameters() - Constructor for class com.teracloud.streams.rest.JobSubmitParameters
- join(Function<T, K>, TWindow<U, K>, BiFunction<T, List<U>, J>) - Method in interface com.teracloud.streams.topology.TStream
-
Join this stream with a partitioned window of type
U
with key typeK
. - join(TWindow<U, ?>, BiFunction<T, List<U>, J>) - Method in interface com.teracloud.streams.topology.TStream
-
Join this stream with window of type
U
. - joinLast(Function<? super T, ? extends K>, TStream<U>, Function<? super U, ? extends K>, BiFunction<T, U, J>) - Method in interface com.teracloud.streams.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.teracloud.streams.topology.TStream
-
Join this stream with the last tuple seen on a stream of type
U
. - JSON - Static variable in interface com.teracloud.streams.topology.json.JSONSchemas
-
Streams schema used for streams with JSON data.
- JSON - Static variable in interface com.teracloud.streams.topology.spl.SPLSchemas
-
SPL schema used to publish and subscribe to
TStream<JSONObject>
streams. - JSONAble - Interface in com.teracloud.streams.topology.tuple
- JSONSchemas - Interface in com.teracloud.streams.topology.json
-
SPL schema for JSON.
- JSONStreams - Class in com.teracloud.streams.topology.json
-
Utilities for JSON streams.
- JSONStreams() - Constructor for class com.teracloud.streams.topology.json.JSONStreams
- JSONStreams.DeserializeJSON - Class in com.teracloud.streams.topology.json
-
Function to deserialize a String to a JSONObject.
- JSONStreams.SerializeJSON - Class in com.teracloud.streams.topology.json
-
Function to serialize a JSONObject to a String.
- JSONStreams.ToJSON<T extends JSONAble> - Class in com.teracloud.streams.topology.json
K
- KafkaConsumer - Class in com.teracloud.streams.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.teracloud.streams.topology.messaging.kafka.KafkaConsumer
-
Create a consumer connector for subscribing to topics.
- KafkaProducer - Class in com.teracloud.streams.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.teracloud.streams.topology.messaging.kafka.KafkaProducer
-
Create a producer connector for publishing tuples.
- KEEP_ARTIFACTS - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Keep any intermediate artifacts.
- key() - Method in interface com.teracloud.streams.topology.TWindow
-
Return a keyed (partitioned) window that has the same configuration as this window with each tuple being the key.
- key(Function<? super T, ? extends U>) - Method in interface com.teracloud.streams.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_PARTITIONED - Enum constant in enum class com.teracloud.streams.topology.TStream.Routing
-
Tuples will be consistently routed to the same channel based upon their key.
- Keyable<K> - Interface in com.teracloud.streams.topology.tuple
-
A tuple that has a partition key.
L
- last() - Method in interface com.teracloud.streams.topology.TStream
-
Declare a
TWindow
that continually represents the last tuple on this stream. - last(int) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a
TWindow
that continually represents the lastcount
tuples seen on this stream. - last(long, TimeUnit) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a
TWindow
that continually represents the lasttime
seconds of tuples (in the given timeunit
) on this stream. - last(Supplier<Integer>) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a
TWindow
that continually represents the lastcount
tuples seen on this stream. - lastSeconds(Supplier<Integer>) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a
TWindow
that continually represents the lasttime
seconds of tuples on this stream. - limitedSource(Supplier<T>, long) - Method in class com.teracloud.streams.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.teracloud.streams.topology.Topology
-
Declare a limited source stream, where the number of tuples is limited to
count
. - Logic - Class in com.teracloud.streams.topology.logic
- Logic() - Constructor for class com.teracloud.streams.topology.logic.Logic
- longBeacon(TopologyElement) - Static method in class com.teracloud.streams.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.teracloud.streams.topology.streams.BeaconStreams
-
Creates a source stream of
count
tuples with no delay between each tuple. - lowLatency() - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Return a stream that is guaranteed to run in the same process as the calling TStream.
- lowLatency() - Method in interface com.teracloud.streams.topology.TStream
-
Return a stream that is guaranteed to run in the same process as the calling TStream.
M
- map(Function<T, U>) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a new stream that maps each tuple from this stream into one (or zero) tuple of a different type
U
. - maxConsecutiveResetAttempts(int) - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Return a new configuration changing
maxConsecutiveResetAttempts
. - Message - Interface in com.teracloud.streams.topology.tuple
-
An interface for tuple attributes common to messaging adapters in
com.teracloud.streams.topology.messaging
. - Metric - Class in com.teracloud.streams.rest
-
An object describing an Streams Metric
- Metric() - Constructor for class com.teracloud.streams.rest.Metric
- modify(UnaryOperator<Tuple>) - Method in interface com.teracloud.streams.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.teracloud.streams.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.teracloud.streams.topology.messaging.mqtt
-
A simple connector to a MQTT broker for publishing
TStream<Message>
tuples to MQTT topics, and subscribing to MQTT topics and creatingTStream<Message>
streams. - MqttStreams(TopologyElement, Map<String, Object>) - Constructor for class com.teracloud.streams.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.teracloud.streams.topology.TStream
-
Declare a new stream that maps tuples from this stream into one or more (or zero) tuples of a different type
U
.
N
- NAME - Static variable in interface com.teracloud.streams.topology.context.JobProperties
-
Name for a submitted application.
- newTopology() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- notKeyed() - Static method in class com.teracloud.streams.topology.logic.Logic
- numbers(Number...) - Method in class com.teracloud.streams.topology.Topology
-
Create a stream of
Number
tuples.
O
- ObjIntConsumer<T> - Interface in com.teracloud.streams.topology.function
- of(T) - Static method in class com.teracloud.streams.topology.logic.Value
-
Return a constant value
Supplier
. - ofAuthenticator(String, Function<Executor, String>) - Static method in class com.teracloud.streams.rest.StreamsConnection
- operator() - Method in interface com.teracloud.streams.topology.context.Placeable
- operator() - Method in interface com.teracloud.streams.topology.TSink
-
Internal method.
- Operator - Class in com.teracloud.streams.rest
-
An object describing an Streams Operator
- Operator() - Constructor for class com.teracloud.streams.rest.Operator
- OPERATOR_DRIVEN - Enum constant in enum class com.teracloud.streams.topology.consistent.ConsistentRegionConfig.Trigger
-
Region is triggered by the start operator.
- operatorDriven() - Static method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Create a
ConsistentRegionConfig.Trigger.OPERATOR_DRIVEN
consistent region configuration. - output() - Method in interface com.teracloud.streams.topology.TStream
-
Internal method.
- OutputPort - Class in com.teracloud.streams.rest
-
An Output Port of the Streams Operator
- OutputPort() - Constructor for class com.teracloud.streams.rest.OutputPort
- OVERRIDE_RESOURCE_LOAD_PROTECTION - Static variable in interface com.teracloud.streams.topology.context.JobProperties
-
Optional override for a submitted application.
P
- parallel(int) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Parallelizes the stream into a a fixed number of parallel channels using round-robin distribution.
- parallel(int) - Method in interface com.teracloud.streams.topology.TStream
-
Parallelizes the stream into a a fixed number of parallel channels using round-robin distribution.
- parallel(Supplier<Integer>) - Method in interface com.teracloud.streams.topology.TStream
-
Parallelizes the stream into
width
parallel channels. - parallel(Supplier<Integer>, Function<Tuple, ?>) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Parallelizes the stream into a number of parallel channels using key based distribution.
- parallel(Supplier<Integer>, Function<T, ?>) - Method in interface com.teracloud.streams.topology.TStream
-
Parallelizes the stream into a number of parallel channels using key based distribution.
- parallel(Supplier<Integer>, TStream.Routing) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Parallelizes the stream into
width
parallel channels. - parallel(Supplier<Integer>, TStream.Routing) - Method in interface com.teracloud.streams.topology.TStream
-
Parallelizes the stream into
width
parallel channels. - PAYLOAD - Static variable in class com.teracloud.streams.topology.json.JSONStreams
-
JSON key for arrays and values.
- PEInputPort - Class in com.teracloud.streams.rest
-
An Input Port of the Streams Processing Element
- PEInputPort() - Constructor for class com.teracloud.streams.rest.PEInputPort
- PEOutputPort - Class in com.teracloud.streams.rest
-
A Output Port of the Streams Processing Element
- PEOutputPort() - Constructor for class com.teracloud.streams.rest.PEOutputPort
- periodic(int) - Static method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Create a
ConsistentRegionConfig.Trigger.PERIODIC
consistent region configuration. - PERIODIC - Enum constant in enum class com.teracloud.streams.topology.consistent.ConsistentRegionConfig.Trigger
-
Region is triggered periodically.
- periodicMultiSource(Supplier<Iterable<T>>, long, TimeUnit) - Method in class com.teracloud.streams.topology.Topology
-
Declare a new source stream that calls
data.get()
periodically. - periodicSource(Supplier<T>, long, TimeUnit) - Method in class com.teracloud.streams.topology.Topology
-
Declare a new source stream that calls
data.get()
periodically. - Placeable<T extends Placeable<T>> - Interface in com.teracloud.streams.topology.context
-
Placement directives for a topology element when executing in a distributed runtime.
- Predicate<T> - Interface in com.teracloud.streams.topology.function
-
A function that tests a tuple.
- PRELOAD_APPLICATION_BUNDLES - Static variable in interface com.teracloud.streams.topology.context.JobProperties
-
Optionally specify whether to preload the job onto all resources in the instance.
- print() - Method in interface com.teracloud.streams.topology.TStream
-
Print each tuple on
System.out
. - process() - Method in class com.teracloud.streams.topology.file.DirectoryWatcher
- process(StreamingInput<Tuple>, Tuple) - Method in class com.teracloud.streams.topology.file.TextFileReader
- ProcessingElement - Class in com.teracloud.streams.rest
-
An object describing an Streams Processing Element
- ProcessingElement() - Constructor for class com.teracloud.streams.rest.ProcessingElement
- publish(Supplier<String>) - Method in interface com.teracloud.streams.topology.TStream
-
Publish tuples from this stream for consumption by other Streams applications.
- publish(Supplier<String>, boolean) - Method in interface com.teracloud.streams.topology.TStream
-
Publish tuples from this stream for consumption by other Streams applications.
- publish(TStream<? extends Message>) - Method in class com.teracloud.streams.topology.messaging.kafka.KafkaProducer
-
Publish a stream of messages to one or more topics.
- publish(TStream<? extends Message>) - Method in class com.teracloud.streams.topology.messaging.mqtt.MqttStreams
-
Publish
stream
tuples to one or more MQTT topics. - publish(TStream<? extends Message>, Supplier<String>) - Method in class com.teracloud.streams.topology.messaging.kafka.KafkaProducer
-
Publish a stream of messages to a topic.
- publish(TStream<? extends Message>, Supplier<String>) - Method in class com.teracloud.streams.topology.messaging.mqtt.MqttStreams
-
Publish
stream
tuples to one or more MQTT topics. - publish(String) - Method in interface com.teracloud.streams.topology.TStream
-
Publish tuples from this stream for consumption by other Streams applications.
- publish(String, boolean) - Method in interface com.teracloud.streams.topology.TStream
-
Publish tuples from this stream for consumption by other Streams applications.
R
- refresh() - Method in class com.teracloud.streams.rest.Element
-
Refresh this element.
- refresh() - Method in class com.teracloud.streams.rest.Metric
- resetConsistentRegions(Integer) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Create a condition that randomly resets consistent regions.
- resetTimeout(long) - Method in class com.teracloud.streams.topology.consistent.ConsistentRegionConfig
-
Return a new configuration changing
resetTimeout
. - Resource - Class in com.teracloud.streams.rest
-
Domain resource information.
- Resource() - Constructor for class com.teracloud.streams.rest.Resource
- ResourceAllocation - Class in com.teracloud.streams.rest
-
Access to information about a resource that is allocated to a Streams instance.
- ResourceAllocation() - Constructor for class com.teracloud.streams.rest.ResourceAllocation
- RESTErrorMessage - Class in com.teracloud.streams.rest
-
An object describing an Streams REST api Error Message
- RESTErrorMessage(String, String) - Constructor for class com.teracloud.streams.rest.RESTErrorMessage
- RESTException - Exception in com.teracloud.streams.rest
-
Exception for REST api wrappers
- RESTException(int) - Constructor for exception com.teracloud.streams.rest.RESTException
-
Customized exception that can provide more information on REST errors
- RESTException(int, String) - Constructor for exception com.teracloud.streams.rest.RESTException
-
Customized exception that can provide more information on REST errors
- RESTException(String) - Constructor for exception com.teracloud.streams.rest.RESTException
-
Customized exception that can provide more information on REST errors
- RESTException(String, Exception) - Constructor for exception com.teracloud.streams.rest.RESTException
-
Customized exception that can provide more information on REST errors
- RestServer - Class in com.teracloud.streams.topology.inet
-
Adds a HTTP REST server to a topology to provide external interaction with the application.
- RestServer(TopologyElement) - Constructor for class com.teracloud.streams.topology.inet.RestServer
-
Create a REST server that will listen on port 8080.
- RestServer(TopologyElement, int) - Constructor for class com.teracloud.streams.topology.inet.RestServer
-
Create a REST server that will listen on the specified port.
- Result<T,
R> - Interface in com.teracloud.streams.rest -
Represents a result from a REST request.
- ResultProperties - Interface in com.teracloud.streams.topology.context
-
Result properties.
- retrieveLogTrace(File) - Method in class com.teracloud.streams.rest.Job
-
Retrieves the application log and trace files of the job and saves them as a compressed tar file.
- ROUND_ROBIN - Enum constant in enum class com.teracloud.streams.topology.TStream.Routing
-
Tuples will be routed to parallel channels such that an even distribution is maintained.
S
- sample(double) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Return a stream that is a random sample of this stream.
- sample(double) - Method in interface com.teracloud.streams.topology.TStream
-
Return a stream that is a random sample of this stream.
- SC_OPTIONS - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Options to be passed to Streams sc command.
- serialize(TStream<JSONObject>) - Static method in class com.teracloud.streams.topology.json.JSONStreams
-
Create a stream of serialized JSON objects as String tuples.
- SerializeJSON() - Constructor for class com.teracloud.streams.topology.json.JSONStreams.SerializeJSON
- setConsistent(ConsistentRegionConfig) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Set the operator that is the source of 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.teracloud.streams.topology.TStream
-
Set the operator that is the source of 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.teracloud.streams.topology.jobconfig.JobConfig
-
Set the data directory.
- setDirectory(String) - Method in class com.teracloud.streams.topology.file.DirectoryWatcher
- setEncoding(String) - Method in class com.teracloud.streams.topology.file.TextFileReader
- setJobGroup(String) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Set the job group.
- setJobName(String) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
-
Set the job name.
- setOverrideResourceLoadProtection(Boolean) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- setParallel(Supplier<Integer>) - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Sets the current stream as the start of a parallel region.
- setParallel(Supplier<Integer>) - Method in interface com.teracloud.streams.topology.TStream
-
Sets the current stream as the start of a parallel region.
- setPreloadApplicationBundles(Boolean) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- setTesterType() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- setTracing(Level) - Method in class com.teracloud.streams.topology.jobconfig.JobConfig
- setValue(Number) - Method in class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- setValue(String) - Method in class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- SimpleMessage - Class in com.teracloud.streams.topology.tuple
-
A Simple implementation of an immutable
Message
. - SimpleMessage(String) - Constructor for class com.teracloud.streams.topology.tuple.SimpleMessage
-
Create a
SimpleMessage
that lacks a key and topic. - SimpleMessage(String, String) - Constructor for class com.teracloud.streams.topology.tuple.SimpleMessage
-
Create a
SimpleMessage
that lacks a topic. - SimpleMessage(String, String, String) - Constructor for class com.teracloud.streams.topology.tuple.SimpleMessage
-
Create a
SimpleMessage
. - single(TopologyElement) - Static method in class com.teracloud.streams.topology.streams.BeaconStreams
-
Produce a source stream declaring a single tuple, with the value 0.
- sink(Consumer<T>) - Method in interface com.teracloud.streams.topology.TStream
-
Terminate this stream.
- skipVersion(String, int...) - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
-
Allow a test to be skipped for a specific version.
- sortAndSubmit(List<File>) - Method in class com.teracloud.streams.topology.file.DirectoryWatcher
- source(Supplier<Iterable<T>>) - Method in class com.teracloud.streams.topology.Topology
-
Declare a new source stream that iterates over the return of
Iterable<T> get()
fromdata
. - SPL - Class in com.teracloud.streams.topology.spl
-
Integration between Java topologies and SPL operator invocations.
- SPL() - Constructor for class com.teracloud.streams.topology.spl.SPL
- splHandler(SPLStream, T) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Deprecated.Since 1.11. In most distributed environments stream contents cannot be obtained due to network isolation. An alternative is to use
stringTupleTester
to perform a per-tuple check. - SPLInput - Interface in com.teracloud.streams.topology.spl
-
Interface that can be connected to an SPL input port.
- split(int, ToIntFunction<T>) - Method in interface com.teracloud.streams.topology.TStream
-
Distribute a stream's tuples among
n
streams as specified by asplitter
. - splOK() - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- SPLSchemas - Interface in com.teracloud.streams.topology.spl
-
Interchangeable SPL types.
- SPLStream - Interface in com.teracloud.streams.topology.spl
-
A
SPLStream
is a declaration of a continuous sequence of tuples with a defined SPL schema. - SPLStreams - Class in com.teracloud.streams.topology.spl
-
Utilities for SPL attribute schema streams.
- SPLStreams() - Constructor for class com.teracloud.streams.topology.spl.SPLStreams
- SPLWindow - Interface in com.teracloud.streams.topology.spl
-
An SPL window, that has an SPL eviction policy and an SPL trigger policy.
- SSL_VERIFY - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Set SSL certification verification state.
- STANDALONE - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
The topology is executed directly as an Streams standalone application.
- STANDALONE_TESTER - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Testing variant of
StreamsContext.Type.STANDALONE
. - startsWith(TStream<String>, String) - Static method in class com.teracloud.streams.topology.streams.StringStreams
-
Create a filtered stream that contains
String
tuples starting with a specific term. - STREAMS_INSTANCE - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Instance connection to Streams REST api to be used for submission.
- StreamsConnection - Class in com.teracloud.streams.rest
-
Connection to Streams.
- StreamsContext<T> - Interface in com.teracloud.streams.topology.context
-
A
StreamsContext
provides the ability to turn aTopology
into an executable. - StreamsContext.Type - Enum Class in com.teracloud.streams.topology.context
-
Types of the
Streams context
that aTopology
can be executed against. - StreamsContextFactory - Class in com.teracloud.streams.topology.context
-
Factory for creating
StreamsContext
instances. - StreamsContextFactory() - Constructor for class com.teracloud.streams.topology.context.StreamsContextFactory
- STRING - Static variable in interface com.teracloud.streams.topology.spl.SPLSchemas
-
SPL schema used by
TStream<String>
streams. - stringContents(TStream<String>, String...) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Return a condition that evaluates if
stream
has submitted at tuples matchingvalues
in the same order. - stringContentsUnordered(TStream<String>, String...) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Return a condition that evaluates if
stream
has submitted at tuples matchingvalues
in any order. - strings(String...) - Method in class com.teracloud.streams.topology.Topology
-
Create a stream of
String
tuples. - StringStreams - Class in com.teracloud.streams.topology.streams
-
Utilities for streams containing
String
tuples. - StringStreams() - Constructor for class com.teracloud.streams.topology.streams.StringStreams
- stringToSPLStream(TStream<String>) - Static method in class com.teracloud.streams.topology.spl.SPLStreams
- stringTupleTester(TStream<String>, Predicate<String>) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Return a condition that evaluates if every tuple on
stream
evaluates totrue
withtester
. - SUBMISSION_PARAMS - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Submission parameters to be supplied to the topology when submitted for
DISTRIBUTED
orSTANDALONE
execution. - SubmissionParameter - Class in com.teracloud.streams.topology.jobconfig
- SubmissionParameter(String, boolean) - Constructor for class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- SubmissionParameter(String, Number) - Constructor for class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- SubmissionParameter(String, String) - Constructor for class com.teracloud.streams.topology.jobconfig.SubmissionParameter
- submit(JsonObject) - Method in interface com.teracloud.streams.topology.context.StreamsContext
-
Submit a topology} to this Streams context as a JSON object.
- submit(Topology) - Method in interface com.teracloud.streams.topology.context.StreamsContext
-
Submit
topology
to this Streams context. - submit(Topology, Map<String, Object>) - Method in interface com.teracloud.streams.topology.context.StreamsContext
-
Submit
topology
to this Streams context with a specific configuration. - submitJob(JsonObject) - Method in class com.teracloud.streams.rest.ApplicationBundle
- submitJob(File, JsonObject) - Method in class com.teracloud.streams.rest.Instance
-
Submit a Streams bundle to run.
- subscribe(Supplier<Integer>, Supplier<String>) - Method in class com.teracloud.streams.topology.messaging.kafka.KafkaConsumer
-
Subscribe to a topic and create a stream of messages.
- subscribe(Supplier<String>) - Method in class com.teracloud.streams.topology.messaging.kafka.KafkaConsumer
-
Subscribe to a topic and create a stream of messages.
- subscribe(Supplier<String>) - Method in class com.teracloud.streams.topology.messaging.mqtt.MqttStreams
-
Subscribe to a MQTT topic and create a stream of messages.
- subscribe(Supplier<String>, Class<T>) - Method in class com.teracloud.streams.topology.Topology
-
Declare a stream that is a subscription to
topic
. - subscribe(TopologyElement, Supplier<String>, StreamSchema) - Static method in class com.teracloud.streams.topology.spl.SPLStreams
-
Subscribe to an
SPLStream
published by topic. - subscribe(TopologyElement, String, StreamSchema) - Static method in class com.teracloud.streams.topology.spl.SPLStreams
-
Subscribe to an
SPLStream
published by topic. - subscribe(String, Class<T>) - Method in class com.teracloud.streams.topology.Topology
-
Declare a stream that is a subscription to
topic
. - suffixFilter(TStream<String>, String...) - Static method in class com.teracloud.streams.topology.file.FileStreams
-
Filter a
Stream<String>
containing file names by suffix values. - Supplier<T> - Interface in com.teracloud.streams.topology.function
-
A function that supplies a value.
T
- tagOpAsJavaPrimitive(BOperatorInvocation, String, String) - Static method in class com.teracloud.streams.topology.spl.SPL
-
Internal method.
- test(T) - Method in interface com.teracloud.streams.topology.function.Predicate
-
Test
tuple
against this predicate. - TEST_TRACE_LEVEL - Static variable in interface com.teracloud.streams.topology.tester.Tester
-
System property to set the trace level of application under tests.
- Tester - Interface in com.teracloud.streams.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.teracloud.streams.topology.tester.junit.TestProperties
- TestProperties - Interface in com.teracloud.streams.topology.tester.junit
- textFileReader(TStream<String>) - Static method in class com.teracloud.streams.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.teracloud.streams.topology.file
- TextFileReader() - Constructor for class com.teracloud.streams.topology.file.TextFileReader
- throttle(long, TimeUnit) - Method in interface com.teracloud.streams.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.teracloud.streams.topology.TStream
-
Throttle a stream by ensuring any tuple is submitted with least
delay
from the previous tuple. - ToIntFunction<T> - Interface in com.teracloud.streams.topology.function
-
A function that applies a computation to a tuple and returns an
int
result. - toJSON() - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Transform SPL tuples into JSON.
- toJSON() - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
-
Creates a JSON object with two attributes:
sequence
Value ofBeaconTuple.getSequence()
time
Value ofBeaconTuple.getTime()
- toJSON() - Method in interface com.teracloud.streams.topology.tuple.JSONAble
- toJSON(TStream<T>) - Static method in class com.teracloud.streams.topology.json.JSONStreams
-
Declare a stream of JSON objects from a stream of Java objects that implement
JSONAble
. - ToJSON() - Constructor for class com.teracloud.streams.topology.json.JSONStreams.ToJSON
- TOOLKIT - Enum constant in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Execution of the topology produces the application as a Streams toolkit.
- TOOLKIT_DIR - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Location of the generated toolkit root.
- topology() - Method in class com.teracloud.streams.topology.inet.RestServer
-
Get the topology for this REST server.
- topology() - Method in class com.teracloud.streams.topology.Topology
-
Return this topology.
- topology() - Method in interface com.teracloud.streams.topology.TopologyElement
-
The topology for this element.
- Topology - Class in com.teracloud.streams.topology
-
A declaration of a topology of streaming data.
- Topology() - Constructor for class com.teracloud.streams.topology.Topology
-
Create an new topology with a default name.
- Topology(String) - Constructor for class com.teracloud.streams.topology.Topology
-
Create an new topology with a given name.
- Topology(String, String) - Constructor for class com.teracloud.streams.topology.Topology
-
Create an new topology with a given name and namespace.
- TOPOLOGY_LOGGER - Static variable in class com.teracloud.streams.topology.Topology
-
Logger used for the Topology API, name
com.teracloud.streams.topology
. - TopologyElement - Interface in com.teracloud.streams.topology
-
Any element in a
Topology
. - toSPL(TStream<JSONObject>) - Static method in class com.teracloud.streams.topology.json.JSONStreams
-
Convert a JSON stream to an SPLStream.
- toString() - Method in class com.teracloud.streams.rest.Element
- toString() - Method in class com.teracloud.streams.rest.RESTErrorMessage
- toString() - Method in class com.teracloud.streams.topology.tuple.BeaconTuple
- toString() - Method in class com.teracloud.streams.topology.tuple.SimpleMessage
- toString(TStream<T>) - Static method in class com.teracloud.streams.topology.streams.StringStreams
-
Create a stream that converts each input tuple to its
String
representation usingtoString()
. - toStringStream() - Method in interface com.teracloud.streams.topology.spl.SPLStream
-
Create a TStream<Tuple> from this stream.
- toStringStream(SPLStream) - Static method in class com.teracloud.streams.topology.spl.SPLStreams
-
Convert an
SPLStream
to a TStream<String> by taking its first attribute. - toStringStream(SPLStream, String) - Static method in class com.teracloud.streams.topology.spl.SPLStreams
-
Convert an
SPLStream
to a TStream<String> by taking a specific attribute. - toTupleString() - Method in interface com.teracloud.streams.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.teracloud.streams.topology.context.ContextProperties
-
Trace level for a
StreamsContext.Type.DISTRIBUTED
orStreamsContext.Type.STANDALONE
application. - transform(Function<T, U>) - Method in interface com.teracloud.streams.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.teracloud.streams.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.teracloud.streams.topology.spl.SPLStreams
-
Convert window to an SPL window with a time based trigger policy.
- TSink - Interface in com.teracloud.streams.topology
-
A handle to the
sink
of aTStream
. - TStream<T> - Interface in com.teracloud.streams.topology
-
A
TStream
is a declaration of a continuous sequence of tuples. - TStream.Routing - Enum Class in com.teracloud.streams.topology
-
Enumeration for routing tuples to parallel channels.
- tupleContents(SPLStream, Tuple...) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Return a condition that evaluates if
stream
has submitted at tuples matchingvalues
in the same order. - tupleCount(TStream<?>, long) - Method in interface com.teracloud.streams.topology.tester.Tester
-
Return a condition that evaluates if
stream
has submitted exactlyexpectedCount
number of tuples. - TWindow<T,
K> - Interface in com.teracloud.streams.topology -
Declares a window of tuples for a
TStream
.
U
- UnaryOperator<T> - Interface in com.teracloud.streams.topology.function
-
Specialization of
Function
where the return type is the same as the argument type. - union(TStream<T>) - Method in interface com.teracloud.streams.topology.TStream
-
Create a stream that is a union of this stream and
other
stream of the same typeT
. - union(Set<TStream<T>>) - Method in interface com.teracloud.streams.topology.TStream
-
Create a stream that is a union of this stream and
others
streams of the same typeT
. - uploadBundle(File) - Method in class com.teracloud.streams.rest.Instance
-
Upload a Streams application bundle (sab) to the instance.
- Util - Class in com.teracloud.streams.topology.messaging.kafka
V
- valid() - Method in interface com.teracloud.streams.topology.tester.Condition
-
Test if this condition is valid.
- Value<T> - Class in com.teracloud.streams.topology.logic
-
A Supplier
for a single constant T value. - Value(T) - Constructor for class com.teracloud.streams.topology.logic.Value
-
Create a constant value
Supplier
. - valueOf(String) - Static method in enum class com.teracloud.streams.topology.consistent.ConsistentRegionConfig.Trigger
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.teracloud.streams.topology.spl.FileSPLStreams.Compression
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.teracloud.streams.topology.TStream.Routing
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.teracloud.streams.topology.consistent.ConsistentRegionConfig.Trigger
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.teracloud.streams.topology.context.StreamsContext.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.teracloud.streams.topology.spl.FileSPLStreams.Compression
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.teracloud.streams.topology.TStream.Routing
-
Returns an array containing the constants of this enum class, in the order they are declared.
- verifyComplete(Tester, Condition<?>) - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- verifyComplete(Tester, Condition<?>, long, TimeUnit) - Method in class com.teracloud.streams.topology.tester.junit.AbstractTestClass
- viewer(TWindow<?, ?>, String, String) - Method in class com.teracloud.streams.topology.inet.RestServer
-
Declare a HTTP REST view of tuples in a window.
- VMARGS - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
-
Java virtual machine arguments.
W
- waitForHealthy(long, TimeUnit) - Method in class com.teracloud.streams.rest.Job
-
Wait for this job to become healthy.
- window(TWindow<?, ?>) - Method in interface com.teracloud.streams.topology.TStream
-
Declare a
TWindow
on this stream that has the same configuration as another window.
X
- XML - Static variable in interface com.teracloud.streams.topology.spl.SPLSchemas
-
SPL schema used by
TStream<com.ibm.streams.operator.types.XML> streams
.
Z
- zlib - Enum constant in enum class com.teracloud.streams.topology.spl.FileSPLStreams.Compression
_
- _SPLMM_OPTIONS - Static variable in interface com.teracloud.streams.topology.context.ContextProperties
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
stringTupleTester
to perform a per-tuple check.