- Checkpoint - Class in org.apache.samza.checkpoint
-
A checkpoint is a mapping of all the streams a job is consuming and the most recent current offset for each.
- Checkpoint(Map<SystemStreamPartition, String>) - Constructor for class org.apache.samza.checkpoint.Checkpoint
-
Constructs a new checkpoint based off a map of Samza stream offsets.
- CheckpointListener - Interface in org.apache.samza.checkpoint
-
This interface should be implemented by SystemConsumers which want to be notified about checkpoint values
of the most recent checkpoint.
- CheckpointManager - Interface in org.apache.samza.checkpoint
-
CheckpointManagers read and write
Checkpoint
to some
implementation-specific location.
- CheckpointManagerFactory - Interface in org.apache.samza.checkpoint
-
- choose() - Method in interface org.apache.samza.system.chooser.MessageChooser
-
The choose method is invoked when the SamzaContainer is ready to process a
new message.
- clear() - Method in class org.apache.samza.config.Config
-
- clear() - Method in class org.apache.samza.metrics.Counter
-
- clearCheckpoints() - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
Clear the checkpoints in the checkpoint stream.
- clearStream(StreamSpec) - Method in interface org.apache.samza.system.SystemAdmin
-
Clear the stream described by the spec.
- Clock - Interface in org.apache.samza.util
-
Mockable interface for tracking time.
- ClosableFunction - Interface in org.apache.samza.operators.functions
-
A function that can be closed after its execution.
- ClosableIterator<V> - Interface in org.apache.samza.storage.kv
-
An iterator that must be closed.
- ClosableTask - Interface in org.apache.samza.task
-
A ClosableTask augments
StreamTask
, allowing the method implementer to specify
code that will be called when the StreamTask is being shut down by the framework, providing to emit final metrics,
clean or close resources, etc.
- close() - Method in interface org.apache.samza.operators.ContextManager
-
Allows closing the custom context that is shared across multiple operator functions in a task.
- close() - Method in interface org.apache.samza.operators.functions.ClosableFunction
-
- close() - Method in interface org.apache.samza.storage.kv.ClosableIterator
-
Closes this iterator and frees resources assigned to it.
- close() - Method in interface org.apache.samza.storage.kv.KeyValueIterator
-
- close() - Method in interface org.apache.samza.storage.kv.KeyValueStore
-
Closes this key-value store, if applicable, relinquishing any underlying resources.
- close() - Method in interface org.apache.samza.task.ClosableTask
-
- CommandBuilder - Class in org.apache.samza.job
-
CommandBuilders are used to customize the command necessary to launch a Samza
Job for a particular framework, such as YARN or the LocalJobRunner.
- CommandBuilder() - Constructor for class org.apache.samza.job.CommandBuilder
-
- commandPath - Variable in class org.apache.samza.job.CommandBuilder
-
- commit(TaskCoordinator.RequestScope) - Method in interface org.apache.samza.task.TaskCoordinator
-
Requests that Samza should write out a checkpoint, from which a task can restart
after failure.
- compareAndSet(T, T) - Method in class org.apache.samza.metrics.Gauge
-
- compareTo(TaskName) - Method in class org.apache.samza.container.TaskName
-
- compareTo(Partition) - Method in class org.apache.samza.Partition
-
- compareTo(SystemStreamPartition) - Method in class org.apache.samza.system.SystemStreamPartition
-
- complete() - Method in interface org.apache.samza.metrics.MetricsValidator
-
Complete validation.
- complete() - Method in interface org.apache.samza.task.TaskCallback
-
Invoke when the asynchronous process completed with success.
- Config - Class in org.apache.samza.config
-
Store and retrieve named, typed values as configuration for classes implementing this interface.
- Config() - Constructor for class org.apache.samza.config.Config
-
- config - Variable in class org.apache.samza.container.SamzaContainerContext
-
- config - Variable in class org.apache.samza.job.CommandBuilder
-
- config - Variable in class org.apache.samza.runtime.ApplicationRunner
-
- ConfigException - Exception in org.apache.samza.config
-
- ConfigException(Throwable) - Constructor for exception org.apache.samza.config.ConfigException
-
- ConfigException(String) - Constructor for exception org.apache.samza.config.ConfigException
-
- ConfigException(String, Throwable) - Constructor for exception org.apache.samza.config.ConfigException
-
- ConfigFactory - Interface in org.apache.samza.config
-
- ConfigRewriter - Interface in org.apache.samza.config
-
A ConfigRewriter receives the job's config during job startup and may re-write it to provide new configs,
remove existing configs or audit and verify the config is correct or permitted.
- containsKey(Object) - Method in class org.apache.samza.config.MapConfig
-
- containsValue(Object) - Method in class org.apache.samza.config.MapConfig
-
- ContextManager - Interface in org.apache.samza.operators
-
Manages custom context that is shared across multiple operator functions in a task.
- ControlMessage - Class in org.apache.samza.system
-
The abstract class of all control messages, containing
the task that produces the control message, the total number of producer tasks,
and a version number.
- ControlMessage(String) - Constructor for class org.apache.samza.system.ControlMessage
-
- copyWithPartitionCount(int) - Method in class org.apache.samza.system.StreamSpec
-
Copies this StreamSpec, but applies a new partitionCount.
- copyWithPhysicalName(String) - Method in class org.apache.samza.system.StreamSpec
-
- count(long) - Static method in class org.apache.samza.operators.triggers.Triggers
-
Creates a
Trigger
that fires when the number of messages in the pane
reaches the specified count.
- Counter - Class in org.apache.samza.metrics
-
A counter is a
Metric
that represents a cumulative value.
- Counter(String) - Constructor for class org.apache.samza.metrics.Counter
-
- counter(Counter) - Method in class org.apache.samza.metrics.MetricsVisitor
-
- CountTrigger<M> - Class in org.apache.samza.operators.triggers
-
A
Trigger
that fires when the number of messages in the
WindowPane
reaches the specified count.
- createChangeLogStreamSpec(String, String, int) - Static method in class org.apache.samza.system.StreamSpec
-
- createCheckpointStreamSpec(String, String) - Static method in class org.apache.samza.system.StreamSpec
-
- createCoordinatorStreamSpec(String, String) - Static method in class org.apache.samza.system.StreamSpec
-
- createInstance() - Method in interface org.apache.samza.task.AsyncStreamTaskFactory
-
- createInstance() - Method in interface org.apache.samza.task.StreamTaskFactory
-
- createStream(StreamSpec) - Method in interface org.apache.samza.system.SystemAdmin
-
Create a stream described by the spec.
- currentTimeMillis() - Method in interface org.apache.samza.util.Clock
-
- Gauge<T> - Class in org.apache.samza.metrics
-
A Gauge is a
Metric
that wraps some instance of T in a thread-safe
reference and allows it to be set or retrieved.
- Gauge(String, T) - Constructor for class org.apache.samza.metrics.Gauge
-
- gauge(Gauge<T>) - Method in class org.apache.samza.metrics.MetricsVisitor
-
- generateProcessorId(Config) - Method in interface org.apache.samza.runtime.ProcessorIdGenerator
-
Generates a String representation to identify a single instance of StreamProcessor.
- get(String, String) - Method in class org.apache.samza.config.Config
-
- get(Object) - Method in class org.apache.samza.config.MapConfig
-
- get(K) - Method in interface org.apache.samza.storage.kv.KeyValueStore
-
Gets the value associated with the specified key
.
- get(String) - Method in class org.apache.samza.system.StreamSpec
-
- getAccumulationMode() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getAdmin(String, Config) - Method in interface org.apache.samza.system.SystemFactory
-
- getAll(List<K>) - Method in interface org.apache.samza.storage.kv.KeyValueStore
-
Gets the values with which the specified keys
are associated.
- getAverage() - Method in class org.apache.samza.metrics.Snapshot
-
Get the average of the values in the collection
- getBoolean(String, boolean) - Method in class org.apache.samza.config.Config
-
- getBoolean(String) - Method in class org.apache.samza.config.Config
-
- getCharacteristic() - Method in class org.apache.samza.operators.triggers.TimeSinceFirstMessageTrigger
-
- getCharacteristic() - Method in class org.apache.samza.operators.triggers.TimeSinceLastMessageTrigger
-
- getCharacteristic() - Method in class org.apache.samza.operators.triggers.TimeTrigger
-
- getCheckpointManager(Config, MetricsRegistry) - Method in interface org.apache.samza.checkpoint.CheckpointManagerFactory
-
- getChooser(Config, MetricsRegistry) - Method in interface org.apache.samza.system.chooser.MessageChooserFactory
-
- getClass(String) - Method in class org.apache.samza.config.Config
-
- getConfig(URI) - Method in interface org.apache.samza.config.ConfigFactory
-
Build a specific Config.
- getConfig() - Method in class org.apache.samza.system.StreamSpec
-
- getConsumer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
-
- getCount() - Method in class org.apache.samza.metrics.Counter
-
- getCount() - Method in class org.apache.samza.operators.triggers.CountTrigger
-
- getCounterValues(String, String) - Method in interface org.apache.samza.metrics.MetricsAccessor
-
Get the values of a counter
- getDate(String) - Method in class org.apache.samza.config.Config
-
- getDate(String, String) - Method in class org.apache.samza.config.Config
-
- getDate(String, SimpleDateFormat) - Method in class org.apache.samza.config.Config
-
- getDate(String, Date) - Method in class org.apache.samza.config.Config
-
- getDate(String, String, Date) - Method in class org.apache.samza.config.Config
-
- getDate(String, SimpleDateFormat, Date) - Method in class org.apache.samza.config.Config
-
- getDefaultTrigger() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getDouble(String, double) - Method in class org.apache.samza.config.Config
-
- getDouble(String) - Method in class org.apache.samza.config.Config
-
- getDuration() - Method in interface org.apache.samza.operators.triggers.TimeBasedTrigger
-
- getDuration() - Method in class org.apache.samza.operators.triggers.TimeSinceFirstMessageTrigger
-
- getDuration() - Method in class org.apache.samza.operators.triggers.TimeSinceLastMessageTrigger
-
- getDuration() - Method in class org.apache.samza.operators.triggers.TimeTrigger
-
- getEarlyTrigger() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getEventTimeExtractor() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getFiringType() - Method in class org.apache.samza.operators.windows.WindowPane
-
- getFirstKey(M) - Method in interface org.apache.samza.operators.functions.JoinFunction
-
Get the join key for messages in the first input stream.
- getFoldLeftFunction() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getGaugeValues(String, String) - Method in interface org.apache.samza.metrics.MetricsAccessor
-
Get the values of a gauge
- getGroup(String) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
-
- getGroups() - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
-
- getId() - Method in class org.apache.samza.system.StreamSpec
-
- getInitializer() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getInputStream(String, Serde<M>) - Method in interface org.apache.samza.operators.StreamGraph
-
- getInputStream(String) - Method in interface org.apache.samza.operators.StreamGraph
-
- getInt(String, int) - Method in class org.apache.samza.config.Config
-
- getInt(String) - Method in class org.apache.samza.config.Config
-
- getJob(Config) - Method in interface org.apache.samza.job.StreamJobFactory
-
- getKey() - Method in class org.apache.samza.operators.KV
-
- getKey() - Method in class org.apache.samza.operators.windows.WindowKey
-
- getKey() - Method in class org.apache.samza.operators.windows.WindowPane
-
- getKey() - Method in class org.apache.samza.storage.kv.Entry
-
- getKey() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
- getKey() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
-
- getKeyExtractor() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getKeySerde() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getKeySerde() - Method in class org.apache.samza.serializers.KVSerde
-
- getKeySerializerName() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
-
- getLateTrigger() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getList(String, List<String>) - Method in class org.apache.samza.config.Config
-
- getList(String) - Method in class org.apache.samza.config.Config
-
- getLong(String, long) - Method in class org.apache.samza.config.Config
-
- getLong(String) - Method in class org.apache.samza.config.Config
-
- getMax() - Method in class org.apache.samza.metrics.Snapshot
-
Get the maximum value in the collection
- getMessage() - Method in class org.apache.samza.operators.windows.WindowPane
-
- getMessage() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
- getMessage() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
-
- getMessageSerializerName() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
-
- getMessagesSizeInQueue(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- getMetricsRegistry() - Method in interface org.apache.samza.task.TaskContext
-
- getMetricsReporter(String, String, Config) - Method in interface org.apache.samza.metrics.MetricsReporterFactory
-
- getMin() - Method in class org.apache.samza.metrics.Snapshot
-
Get the minimum value in the collection
- getMode() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getMsgSerde() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getName() - Method in class org.apache.samza.metrics.Counter
-
- getName() - Method in class org.apache.samza.metrics.Gauge
-
- getName() - Method in class org.apache.samza.metrics.Timer
-
Get the name of the timer
- getNewestOffset(SystemStreamPartition, Integer) - Method in interface org.apache.samza.system.ExtendedSystemAdmin
-
- getNewestOffset() - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
-
- getNewInstance(String) - Method in class org.apache.samza.config.Config
-
- getNumMessagesInQueue(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- getOffset() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
- getOffset(SystemStreamMetadata.OffsetType) - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
-
- getOffsets() - Method in class org.apache.samza.checkpoint.Checkpoint
-
Gets a unmodifiable view of the current Samza stream offsets.
- getOffsetsAfter(Map<SystemStreamPartition, String>) - Method in interface org.apache.samza.system.SystemAdmin
-
Fetches the offsets for the messages immediately after the supplied offsets
for a group of SystemStreamPartitions.
- getOffsetsAfter(Map<SystemStreamPartition, String>) - Method in class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
-
- getOldestOffset() - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
-
- getOrDefault(String, String) - Method in class org.apache.samza.system.StreamSpec
-
- getOutputStream(String, Serde<M>) - Method in interface org.apache.samza.operators.StreamGraph
-
- getOutputStream(String) - Method in interface org.apache.samza.operators.StreamGraph
-
- getOutputWatermark() - Method in interface org.apache.samza.operators.functions.WatermarkFunction
-
Returns the output watermark.
- getPaneId() - Method in class org.apache.samza.operators.windows.WindowKey
-
- getPartition() - Method in class org.apache.samza.system.SystemStreamPartition
-
- getPartitionCount() - Method in class org.apache.samza.system.StreamSpec
-
- getPartitionId() - Method in class org.apache.samza.Partition
-
- getPartitionKey() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
-
- getPhysicalName() - Method in class org.apache.samza.system.StreamSpec
-
- getProducer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
-
- getSamzaContainerContext() - Method in interface org.apache.samza.task.TaskContext
-
- getSecondKey(JM) - Method in interface org.apache.samza.operators.functions.JoinFunction
-
Get the join key for messages in the second input stream.
- getSerde(String, Config) - Method in class org.apache.samza.serializers.ByteBufferSerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.ByteSerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.DoubleSerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.IntegerSerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.JsonSerdeV2Factory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.LongSerdeFactory
-
- getSerde(String, Config) - Method in interface org.apache.samza.serializers.SerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.SerializableSerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.StringSerdeFactory
-
- getSerde(String, Config) - Method in class org.apache.samza.serializers.UUIDSerdeFactory
-
- getShort(String, short) - Method in class org.apache.samza.config.Config
-
- getShort(String) - Method in class org.apache.samza.config.Config
-
- getSize() - Method in class org.apache.samza.metrics.Snapshot
-
Get the number of values in the collection
- getSize() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
- getSnapshot() - Method in interface org.apache.samza.metrics.Reservoir
-
- getSnapshot() - Method in class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
- getSnapshot() - Method in class org.apache.samza.metrics.Timer
-
- getStatus() - Method in interface org.apache.samza.job.StreamJob
-
- getStatusCode() - Method in class org.apache.samza.job.ApplicationStatus
-
- getStorageEngine(String, File, Serde<K>, Serde<V>, MessageCollector, MetricsRegistry, SystemStreamPartition, SamzaContainerContext) - Method in interface org.apache.samza.storage.StorageEngineFactory
-
Create an instance of the given storage engine.
- getStore(String) - Method in interface org.apache.samza.task.TaskContext
-
- getStoreProperties() - Method in interface org.apache.samza.storage.StorageEngine
-
Get store properties
- getStream() - Method in class org.apache.samza.system.SystemStream
-
- getStreamName() - Method in class org.apache.samza.system.SystemStreamMetadata
-
- getStreamSpec(String) - Method in class org.apache.samza.runtime.ApplicationRunner
-
Constructs a
StreamSpec
from the configuration for the specified streamId.
- getSum() - Method in class org.apache.samza.metrics.Snapshot
-
Get the sum of values in the collection
- getSystem() - Method in class org.apache.samza.system.SystemStream
-
- getSystemName() - Method in class org.apache.samza.system.StreamSpec
-
- getSystemStream() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
-
- getSystemStream() - Method in class org.apache.samza.system.SystemStreamPartition
-
- getSystemStreamMetadata(Set<String>) - Method in interface org.apache.samza.system.SystemAdmin
-
Fetch metadata from a system for a set of streams.
- getSystemStreamMetadata(Set<String>) - Method in class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
-
- getSystemStreamPartition() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
- getSystemStreamPartitionCounts(Set<String>, long) - Method in interface org.apache.samza.system.ExtendedSystemAdmin
-
- getSystemStreamPartitionGrouper(Config) - Method in interface org.apache.samza.container.grouper.stream.SystemStreamPartitionGrouperFactory
-
- getSystemStreamPartitionMetadata() - Method in class org.apache.samza.system.SystemStreamMetadata
-
- getSystemStreamPartitions() - Method in interface org.apache.samza.task.TaskContext
-
- getTaskName() - Method in class org.apache.samza.container.TaskName
-
- getTaskName() - Method in class org.apache.samza.system.ControlMessage
-
- getTaskName() - Method in interface org.apache.samza.task.TaskContext
-
- getThrowable() - Method in class org.apache.samza.job.ApplicationStatus
-
- getTimerValues(String, String) - Method in interface org.apache.samza.metrics.MetricsAccessor
-
Get the values of a timer
- getTimestamp() - Method in class org.apache.samza.system.WatermarkMessage
-
- getTrigger() - Method in class org.apache.samza.operators.triggers.RepeatingTrigger
-
- getTriggers() - Method in class org.apache.samza.operators.triggers.AnyTrigger
-
- getUpcomingOffset() - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
-
- getUserContext() - Method in interface org.apache.samza.task.TaskContext
-
Gets the user-defined context.
- getValue() - Method in class org.apache.samza.metrics.Gauge
-
- getValue() - Method in class org.apache.samza.operators.KV
-
- getValue() - Method in class org.apache.samza.storage.kv.Entry
-
- getValue() - Method in class org.apache.samza.util.BlockingEnvelopeMap.BufferGauge
-
- getValue() - Method in class org.apache.samza.util.BlockingEnvelopeMap.BufferSizeGauge
-
- getValues() - Method in class org.apache.samza.metrics.Snapshot
-
Return the entire list of values
- getValueSerde() - Method in class org.apache.samza.serializers.KVSerde
-
- getVersion() - Method in class org.apache.samza.system.ControlMessage
-
- getWindowType() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getWindowValSerde() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- group(Set<SystemStreamPartition>) - Method in interface org.apache.samza.container.grouper.stream.SystemStreamPartitionGrouper
-
- id - Variable in class org.apache.samza.container.SamzaContainerContext
-
- id - Variable in class org.apache.samza.job.CommandBuilder
-
- inc() - Method in class org.apache.samza.metrics.Counter
-
- inc(long) - Method in class org.apache.samza.metrics.Counter
-
- incBlockingPoll(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
-
- incBlockingTimeoutPoll(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
-
- IncomingMessageEnvelope - Class in org.apache.samza.system
-
This class represents a message envelope that is received by a StreamTask for each message that is received from a
partition of a specific input stream.
- IncomingMessageEnvelope(SystemStreamPartition, String, Object, Object) - Constructor for class org.apache.samza.system.IncomingMessageEnvelope
-
Constructs a new IncomingMessageEnvelope from specified components.
- IncomingMessageEnvelope(SystemStreamPartition, String, Object, Object, int) - Constructor for class org.apache.samza.system.IncomingMessageEnvelope
-
Constructs a new IncomingMessageEnvelope from specified components.
- incPoll() - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
-
- init(StreamGraph, Config) - Method in interface org.apache.samza.application.StreamApplication
-
Describes and initializes the transforms for processing message streams and generating results.
- init(Config) - Method in interface org.apache.samza.metrics.MetricsValidator
-
Initialize with config.
- init(Config, TaskContext) - Method in interface org.apache.samza.operators.ContextManager
-
Allows initializing and setting a custom context that is shared across multiple operator functions in a task.
- init(Config, TaskContext) - Method in interface org.apache.samza.operators.functions.InitableFunction
-
Initializes the function before any messages are processed.
- init(Config) - Method in interface org.apache.samza.sql.udfs.ScalarUdf
-
Udfs can implement this method to perform any initialization that they may need.
- init(Config, TaskContext) - Method in interface org.apache.samza.task.InitableTask
-
Called by TaskRunner each time an implementing task is created.
- InitableFunction - Interface in org.apache.samza.operators.functions
-
A function that can be initialized before execution.
- InitableTask - Interface in org.apache.samza.task
-
Used as an interface for user processing StreamTasks that need to have specific functionality performed as their StreamTasks
are instantiated by TaskRunner.
- initMetrics(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
-
- IntegerSerde - Class in org.apache.samza.serializers
-
A serializer for integers
- IntegerSerde() - Constructor for class org.apache.samza.serializers.IntegerSerde
-
- IntegerSerdeFactory - Class in org.apache.samza.serializers
-
- IntegerSerdeFactory() - Constructor for class org.apache.samza.serializers.IntegerSerdeFactory
-
- InterfaceStability - Class in org.apache.samza.annotation
-
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.samza.annotation.InterfaceStability
-
- InterfaceStability.Evolving - Annotation Type in org.apache.samza.annotation
-
Evolving, but can break compatibility at minor release (i.e.
- InterfaceStability.Stable - Annotation Type in org.apache.samza.annotation
-
Can evolve while retaining compatibility for minor release boundaries.;
can break compatibility only at major release (ie.
- InterfaceStability.Unstable - Annotation Type in org.apache.samza.annotation
-
No guarantee is provided as to reliability or stability across any
level of release granularity.
- isAtHead(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- isBounded() - Method in class org.apache.samza.system.StreamSpec
-
- isChangeLogStream() - Method in class org.apache.samza.system.StreamSpec
-
- isCoordinatorStream() - Method in class org.apache.samza.system.StreamSpec
-
- isEmpty() - Method in class org.apache.samza.config.MapConfig
-
- isEndOfStream() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
- isLoggedStore() - Method in class org.apache.samza.storage.StoreProperties
-
Flag to indicate whether a store is associated with a changelog (used for recovery) or not
- isPersistedToDisk() - Method in class org.apache.samza.storage.StoreProperties
-
Flag to indicate whether a store can be persisted to disk or not
- SamzaContainerContext - Class in org.apache.samza.container
-
A SamzaContainerContext maintains per-container information for the tasks it executes.
- SamzaContainerContext(String, Config, Collection<TaskName>, MetricsRegistry) - Constructor for class org.apache.samza.container.SamzaContainerContext
-
An immutable context object that can passed to tasks to give them information
about the container in which they are executing.
- SamzaException - Exception in org.apache.samza
-
Unchecked exception that Samza throws when something goes wrong.
- SamzaException() - Constructor for exception org.apache.samza.SamzaException
-
- SamzaException(String, Throwable) - Constructor for exception org.apache.samza.SamzaException
-
- SamzaException(String) - Constructor for exception org.apache.samza.SamzaException
-
- SamzaException(Throwable) - Constructor for exception org.apache.samza.SamzaException
-
- sanitize() - Method in class org.apache.samza.config.Config
-
- sanitize() - Method in class org.apache.samza.config.MapConfig
-
- ScalarUdf - Interface in org.apache.samza.sql.udfs
-
The base class for the Scalar UDFs.
- send(String, OutgoingMessageEnvelope) - Method in interface org.apache.samza.system.SystemProducer
-
Sends a specified message envelope from a specified Samza source.
- send(OutgoingMessageEnvelope) - Method in interface org.apache.samza.task.MessageCollector
-
Sends message envelope out onto specified stream.
- sendTo(OutputStream<M>) - Method in interface org.apache.samza.operators.MessageStream
-
- SENSITIVE_MASK - Static variable in class org.apache.samza.config.Config
-
- SENSITIVE_PREFIX - Static variable in class org.apache.samza.config.Config
-
- Serde<T> - Interface in org.apache.samza.serializers
-
A Serde is a convenience type that implements both the
Serializer
and
Deserializer
interfaces, allowing it to both read and write data
in its value type, T.
- SerdeFactory<T> - Interface in org.apache.samza.serializers
-
Build an instance of
Serde
- SerializableSerde<T extends java.io.Serializable> - Class in org.apache.samza.serializers
-
A serializer for Serializable objects
- SerializableSerde() - Constructor for class org.apache.samza.serializers.SerializableSerde
-
- SerializableSerdeFactory<T extends java.io.Serializable> - Class in org.apache.samza.serializers
-
- SerializableSerdeFactory() - Constructor for class org.apache.samza.serializers.SerializableSerdeFactory
-
- Serializer<T> - Interface in org.apache.samza.serializers
-
A standard interface for Samza compatible serializers, used for serializing objects to bytes.
- set(long) - Method in class org.apache.samza.metrics.Counter
-
- set(T) - Method in class org.apache.samza.metrics.Gauge
-
- setAccumulationMode(AccumulationMode) - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- setAccumulationMode(AccumulationMode) - Method in interface org.apache.samza.operators.windows.Window
-
- setCommandPath(String) - Method in class org.apache.samza.job.CommandBuilder
-
- setConfig(Config) - Method in class org.apache.samza.job.CommandBuilder
-
- setDefaultSerde(Serde<?>) - Method in interface org.apache.samza.operators.StreamGraph
-
Sets the default
Serde
to use for (de)serializing messages.
- setEarlyTrigger(Trigger<M>) - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- setEarlyTrigger(Trigger<M>) - Method in interface org.apache.samza.operators.windows.Window
-
Set the early triggers for this
Window
.
- setId(String) - Method in class org.apache.samza.job.CommandBuilder
-
- setIsAtHead(SystemStreamPartition, boolean) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- setLateTrigger(Trigger<M>) - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- setLateTrigger(Trigger<M>) - Method in interface org.apache.samza.operators.windows.Window
-
Set the late triggers for this
Window
.
- setLoggedStore(boolean) - Method in class org.apache.samza.storage.StoreProperties.StorePropertiesBuilder
-
- setNoMoreMessages(SystemStreamPartition, boolean) - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
-
- setPersistedToDisk(boolean) - Method in class org.apache.samza.storage.StoreProperties.StorePropertiesBuilder
-
- setStartingOffset(SystemStreamPartition, String) - Method in interface org.apache.samza.task.TaskContext
-
- setUrl(URL) - Method in class org.apache.samza.job.CommandBuilder
-
- setUserContext(Object) - Method in interface org.apache.samza.task.TaskContext
-
Sets the user-defined context.
- setVersion(int) - Method in class org.apache.samza.system.ControlMessage
-
- shutdown(TaskCoordinator.RequestScope) - Method in interface org.apache.samza.task.TaskCoordinator
-
Requests that the container should be shut down.
- SinglePartitionWithoutOffsetsSystemAdmin - Class in org.apache.samza.util
-
A simple helper admin class that defines a single partition (partition 0) for
a given system.
- SinglePartitionWithoutOffsetsSystemAdmin() - Constructor for class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
-
- sink(SinkFunction<? super M>) - Method in interface org.apache.samza.operators.MessageStream
-
- SinkFunction<M> - Interface in org.apache.samza.operators.functions
-
Allows sending a message to an output system.
- size() - Method in class org.apache.samza.config.MapConfig
-
- size() - Method in interface org.apache.samza.metrics.Reservoir
-
Return the number of values in this reservoir
- size() - Method in class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
- SlidingTimeWindowReservoir - Class in org.apache.samza.metrics
-
An implemented
Reservoir
used to store values that appear in a
sliding time window
- SlidingTimeWindowReservoir() - Constructor for class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
Default constructor using default window size
- SlidingTimeWindowReservoir(long) - Constructor for class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
Construct the SlidingTimeWindowReservoir with window size
- SlidingTimeWindowReservoir(long, Clock) - Constructor for class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
- SlidingTimeWindowReservoir(long, int, Clock) - Constructor for class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
- Snapshot - Class in org.apache.samza.metrics
-
A statistical snapshot of a collection of values
- start() - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
- start() - Method in interface org.apache.samza.metrics.MetricsReporter
-
- start() - Method in class org.apache.samza.system.chooser.BaseMessageChooser
-
- start() - Method in interface org.apache.samza.system.chooser.MessageChooser
-
Called after all SystemStreamPartitions have been registered.
- start() - Method in interface org.apache.samza.system.SystemConsumer
-
Tells the SystemConsumer to connect to the underlying system, and prepare
to begin serving messages when poll is invoked.
- start() - Method in interface org.apache.samza.system.SystemProducer
-
Start the SystemProducer.
- status(StreamApplication) - Method in class org.apache.samza.runtime.ApplicationRunner
-
- stop() - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
Perform teardown operations for the Manager.
- stop() - Method in interface org.apache.samza.metrics.MetricsReporter
-
- stop() - Method in interface org.apache.samza.storage.StorageEngine
-
Close the storage engine
- stop() - Method in class org.apache.samza.system.chooser.BaseMessageChooser
-
- stop() - Method in interface org.apache.samza.system.chooser.MessageChooser
-
Called when the chooser is about to be discarded.
- stop() - Method in interface org.apache.samza.system.SystemConsumer
-
Tells the SystemConsumer to close all connections, release all resource,
and shut down everything.
- stop() - Method in interface org.apache.samza.system.SystemProducer
-
Stop the SystemProducer.
- StorageEngine - Interface in org.apache.samza.storage
-
A storage engine for managing state maintained by a stream processor.
- StorageEngineFactory<K,V> - Interface in org.apache.samza.storage
-
An object provided by the storage engine implementation to create instances
of the given storage engine type.
- StoreProperties - Class in org.apache.samza.storage
-
Immutable class that defines the properties of a Store
- StoreProperties.StorePropertiesBuilder - Class in org.apache.samza.storage
-
- StorePropertiesBuilder() - Constructor for class org.apache.samza.storage.StoreProperties.StorePropertiesBuilder
-
- stream - Variable in class org.apache.samza.system.SystemStream
-
- StreamApplication - Interface in org.apache.samza.application
-
Describes and initializes the transforms for processing message streams and generating results.
- StreamGraph - Interface in org.apache.samza.operators
-
- StreamJob - Interface in org.apache.samza.job
-
A StreamJob runs Samza
StreamTask
s in its specific environment.
- StreamJobFactory - Interface in org.apache.samza.job
-
- StreamSpec - Class in org.apache.samza.system
-
StreamSpec is a blueprint for creating, validating, or simply describing a stream in the runtime environment.
- StreamSpec(String, String, String) - Constructor for class org.apache.samza.system.StreamSpec
-
- StreamSpec(String, String, String, int) - Constructor for class org.apache.samza.system.StreamSpec
-
- StreamSpec(String, String, String, boolean, Map<String, String>) - Constructor for class org.apache.samza.system.StreamSpec
-
- StreamSpec(String, String, String, int, boolean, Map<String, String>) - Constructor for class org.apache.samza.system.StreamSpec
-
- StreamTask - Interface in org.apache.samza.task
-
A StreamTask is the basic class on which Samza jobs are implemented.
- StreamTaskFactory - Interface in org.apache.samza.task
-
- StreamValidationException - Exception in org.apache.samza.system
-
- StreamValidationException(String) - Constructor for exception org.apache.samza.system.StreamValidationException
-
- StringSerde - Class in org.apache.samza.serializers
-
A serializer for strings
- StringSerde(String) - Constructor for class org.apache.samza.serializers.StringSerde
-
- StringSerde() - Constructor for class org.apache.samza.serializers.StringSerde
-
- StringSerdeFactory - Class in org.apache.samza.serializers
-
- StringSerdeFactory() - Constructor for class org.apache.samza.serializers.StringSerdeFactory
-
- submit() - Method in interface org.apache.samza.job.StreamJob
-
Submit this job to be run.
- subset(String) - Method in class org.apache.samza.config.Config
-
- subset(String, boolean) - Method in class org.apache.samza.config.Config
-
- SuccessfulFinish - Static variable in class org.apache.samza.job.ApplicationStatus
-
- system - Variable in class org.apache.samza.system.SystemStream
-
- SystemAdmin - Interface in org.apache.samza.system
-
Helper interface attached to an underlying system to fetch information about
streams, partitions, offsets, etc.
- SystemConsumer - Interface in org.apache.samza.system
-
SystemConsumer is the interface that must be implemented by any system that
wishes to integrate with Samza.
- SystemFactory - Interface in org.apache.samza.system
-
- SystemProducer - Interface in org.apache.samza.system
-
SystemProducers are how Samza writes messages from
StreamTask
s to outside systems,
such as messaging systems like Kafka, or file systems.
- SystemProducerException - Exception in org.apache.samza.system
-
- SystemProducerException(String) - Constructor for exception org.apache.samza.system.SystemProducerException
-
- SystemProducerException(Throwable) - Constructor for exception org.apache.samza.system.SystemProducerException
-
- SystemProducerException(String, Throwable) - Constructor for exception org.apache.samza.system.SystemProducerException
-
- SystemStream - Class in org.apache.samza.system
-
Streams in Samza consist of both the stream name and the system to which the stream belongs.
- SystemStream(String, String) - Constructor for class org.apache.samza.system.SystemStream
-
Constructs a Samza stream object from specified components.
- SystemStream(SystemStream) - Constructor for class org.apache.samza.system.SystemStream
-
Constructs a Samza stream object based upon an existing Samza stream.
- SystemStreamMetadata - Class in org.apache.samza.system
-
SystemAdmins use this class to return useful metadata about a stream's offset
and partition information.
- SystemStreamMetadata(String, Map<Partition, SystemStreamMetadata.SystemStreamPartitionMetadata>) - Constructor for class org.apache.samza.system.SystemStreamMetadata
-
- SystemStreamMetadata.OffsetType - Enum in org.apache.samza.system
-
OffsetType is an enum used to define which offset should be used when
reading from a SystemStreamPartition for the first time.
- SystemStreamMetadata.SystemStreamPartitionMetadata - Class in org.apache.samza.system
-
Provides offset information for a given SystemStreamPartition.
- SystemStreamPartition - Class in org.apache.samza.system
-
- SystemStreamPartition(String, String, Partition) - Constructor for class org.apache.samza.system.SystemStreamPartition
-
Constructs a Samza stream partition object from specified components.
- SystemStreamPartition(SystemStreamPartition) - Constructor for class org.apache.samza.system.SystemStreamPartition
-
Constructs a Samza stream partition object based upon an existing Samza stream partition.
- SystemStreamPartition(SystemStream, Partition) - Constructor for class org.apache.samza.system.SystemStreamPartition
-
Constructs a Samza stream partition object based upon another Samza stream and a specified partition.
- SystemStreamPartitionGrouper - Interface in org.apache.samza.container.grouper.stream
-
Group a set of SystemStreamPartitions into logical taskNames that share a common characteristic, defined
by the implementation.
- SystemStreamPartitionGrouperFactory - Interface in org.apache.samza.container.grouper.stream
-
Return an instance a SystemStreamPartitionGrouper per the particular implementation
- SystemStreamPartitionIterator - Class in org.apache.samza.system
-
- SystemStreamPartitionIterator(SystemConsumer, SystemStreamPartition) - Constructor for class org.apache.samza.system.SystemStreamPartitionIterator
-
- SystemStreamPartitionIterator(SystemConsumer, SystemStreamPartition, int) - Constructor for class org.apache.samza.system.SystemStreamPartitionIterator
-
- SystemStreamPartitionMatcher - Interface in org.apache.samza.system
-
- SystemStreamPartitionMetadata(String, String, String) - Constructor for class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
-
- validate(MetricsAccessor) - Method in interface org.apache.samza.metrics.MetricsValidator
-
Validate the metrics values of a job
- validateStream(StreamSpec) - Method in interface org.apache.samza.system.SystemAdmin
-
Validates the stream described by the streamSpec on the system.
- value - Variable in class org.apache.samza.operators.KV
-
- valueOf(String) - Static method in enum org.apache.samza.job.ApplicationStatus.StatusCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.operators.triggers.DurationCharacteristic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.operators.triggers.FiringType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.operators.windows.AccumulationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.operators.windows.internal.WindowType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.system.MessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.system.SystemStreamMetadata.OffsetType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.task.TaskCoordinator.RequestScope
-
Returns the enum constant of this type with the specified name.
- values() - Method in class org.apache.samza.config.MapConfig
-
- values() - Static method in enum org.apache.samza.job.ApplicationStatus.StatusCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.operators.triggers.DurationCharacteristic
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.operators.triggers.FiringType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.operators.windows.AccumulationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.operators.windows.internal.WindowType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.system.MessageType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.system.SystemStreamMetadata.OffsetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.task.TaskCoordinator.RequestScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- visit(MetricsVisitor) - Method in class org.apache.samza.metrics.Counter
-
- visit(MetricsVisitor) - Method in class org.apache.samza.metrics.Gauge
-
- visit(MetricsVisitor) - Method in interface org.apache.samza.metrics.Metric
-
- visit(Metric) - Method in class org.apache.samza.metrics.MetricsVisitor
-
- visit(MetricsVisitor) - Method in class org.apache.samza.metrics.Timer
-