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

A

ApplicationStatus - Enum in org.apache.samza.job
Status of a StreamJob during and after its run.

B

BaseMessageChooser - Class in org.apache.samza.system.chooser
An abstract MessageChooser that implements start/stop/register for choosers that don't use them.
BaseMessageChooser() - Constructor for class org.apache.samza.system.chooser.BaseMessageChooser
 
BLOCK_ON_OUTSTANDING_MESSAGES - Static variable in interface org.apache.samza.system.SystemConsumer
A constant that can be used in the poll method's timeout parameter to denote that the poll invocation should block until at least one message is available for one of the SystemStreamPartitions supplied, or until all SystemStreamPartitions supplied are at head (have no new messages available since the last poll invocation was made for each SystemStreamPartition).
BlockingEnvelopeMap - Class in org.apache.samza.util
BlockingEnvelopeMap is a helper class for SystemConsumer implementations.
BlockingEnvelopeMap() - Constructor for class org.apache.samza.util.BlockingEnvelopeMap
 
BlockingEnvelopeMap(Clock) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap
 
BlockingEnvelopeMap(MetricsRegistry) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap
 
BlockingEnvelopeMap(MetricsRegistry, Clock) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap
 
BlockingEnvelopeMap(MetricsRegistry, Clock, String) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap
 
BlockingEnvelopeMap.BlockingEnvelopeMapMetrics - Class in org.apache.samza.util
 
BlockingEnvelopeMap.BufferGauge - Class in org.apache.samza.util
 
BlockingEnvelopeMapMetrics(String, MetricsRegistry) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
 
BufferGauge(SystemStreamPartition, String) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap.BufferGauge
 
buildCommand() - Method in class org.apache.samza.job.CommandBuilder
 
buildEnvironment() - Method in class org.apache.samza.job.CommandBuilder
 

C

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.
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
 
Clock - Interface in org.apache.samza.util
Mockable interface for tracking time.
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.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
 
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
 
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
 
ConfigException - Exception in org.apache.samza.config
Specific SamzaExceptions thrown from 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
Build a 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
 
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
 
createChangelogStream(String, int) - Method in interface org.apache.samza.system.SystemAdmin
An API to create a change log stream
createChangelogStream(String, int) - Method in class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
 
currentTimeMillis() - Method in interface org.apache.samza.util.Clock
 

D

dec() - Method in class org.apache.samza.metrics.Counter
 
dec(long) - Method in class org.apache.samza.metrics.Counter
 
Deserializer<T> - Interface in org.apache.samza.serializers
A standard interface for Samza compatible deserializers, used for deserializing serialized objects back to their original form.

E

entrySet() - Method in class org.apache.samza.config.MapConfig
 
equals(Object) - Method in class org.apache.samza.checkpoint.Checkpoint
 
equals(Object) - Method in class org.apache.samza.config.MapConfig
 
equals(Object) - Method in class org.apache.samza.container.TaskName
 
equals(Object) - Method in class org.apache.samza.Partition
 
equals(Object) - Method in class org.apache.samza.system.IncomingMessageEnvelope
 
equals(Object) - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
equals(Object) - Method in class org.apache.samza.system.SystemStream
 
equals(Object) - Method in class org.apache.samza.system.SystemStreamMetadata
 
equals(Object) - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
 
equals(Object) - Method in class org.apache.samza.system.SystemStreamPartition
 

F

flush() - Method in interface org.apache.samza.storage.StorageEngine
Flush any cached messages
flush(String) - Method in interface org.apache.samza.system.SystemProducer
If the SystemProducer buffers messages before sending them to its underlying system, it should flush those messages and leave no messages remaining to be sent.
fromBytes(byte[]) - Method in interface org.apache.samza.serializers.Deserializer
Deserializes given serialized object from an array of bytes to its original form.

G

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
 
get(String, String) - Method in class org.apache.samza.config.Config
 
get(Object) - Method in class org.apache.samza.config.MapConfig
 
getAdmin(String, Config) - Method in interface org.apache.samza.system.SystemFactory
 
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
 
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.
getConsumer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
 
getCount() - Method in class org.apache.samza.metrics.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
 
getDouble(String, double) - Method in class org.apache.samza.config.Config
 
getDouble(String) - Method in class org.apache.samza.config.Config
 
getGroup(String) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
 
getGroups() - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
 
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.system.IncomingMessageEnvelope
 
getKey() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
getKeySerializerName() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
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.system.IncomingMessageEnvelope
 
getMessage() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
getMessageSerializerName() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
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
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() - 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
 
getPartition() - Method in class org.apache.samza.system.SystemStreamPartition
 
getPartitionId() - Method in class org.apache.samza.Partition
 
getPartitionKey() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
getProducer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
 
getSerde(String, Config) - Method in interface org.apache.samza.serializers.SerdeFactory
 
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
getSnapshot() - Method in interface org.apache.samza.metrics.Reservoir
Return a Snapshot of this reservoir
getSnapshot() - Method in class org.apache.samza.metrics.SlidingTimeWindowReservoir
 
getSnapshot() - Method in class org.apache.samza.metrics.Timer
Get the Snapshot
getStatus() - Method in interface org.apache.samza.job.StreamJob
Get current ApplicationStatus of the job
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
 
getStream() - Method in class org.apache.samza.system.SystemStream
 
getStreamName() - Method in class org.apache.samza.system.SystemStreamMetadata
 
getSystem() - Method in class org.apache.samza.system.SystemStream
 
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
 
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 interface org.apache.samza.task.TaskContext
 
getUpcomingOffset() - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
 
getValue() - Method in class org.apache.samza.metrics.Gauge
 
getValue() - Method in class org.apache.samza.util.BlockingEnvelopeMap.BufferGauge
 
getValues() - Method in class org.apache.samza.metrics.Snapshot
Return the entire list of values
group(Set<SystemStreamPartition>) - Method in interface org.apache.samza.container.grouper.stream.SystemStreamPartitionGrouper
 

H

hash - Variable in class org.apache.samza.system.SystemStreamPartition
 
hashCode() - Method in class org.apache.samza.checkpoint.Checkpoint
 
hashCode() - Method in class org.apache.samza.config.MapConfig
 
hashCode() - Method in class org.apache.samza.container.TaskName
 
hashCode() - Method in class org.apache.samza.Partition
 
hashCode() - Method in class org.apache.samza.system.IncomingMessageEnvelope
 
hashCode() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
hashCode() - Method in class org.apache.samza.system.SystemStream
 
hashCode() - Method in class org.apache.samza.system.SystemStreamMetadata
 
hashCode() - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
 
hashCode() - Method in class org.apache.samza.system.SystemStreamPartition
 
hasNext() - Method in class org.apache.samza.system.SystemStreamPartitionIterator
 

I

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.
incPoll() - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
 
init(Config, TaskContext) - Method in interface org.apache.samza.task.InitableTask
Called by TaskRunner each time an implementing task is created.
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
 
isAtHead(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap
 
isEmpty() - Method in class org.apache.samza.config.MapConfig
 

K

keySet() - Method in class org.apache.samza.config.MapConfig
 
kill() - Method in interface org.apache.samza.job.StreamJob
Kill this job immediately.

L

listen(ReadableMetricsRegistryListener) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
 

M

MapConfig - Class in org.apache.samza.config
A Config backed by a Java Map
MapConfig() - Constructor for class org.apache.samza.config.MapConfig
 
MapConfig(Map<String, String>) - Constructor for class org.apache.samza.config.MapConfig
 
MapConfig(List<Map<String, String>>) - Constructor for class org.apache.samza.config.MapConfig
 
MessageChooser - Interface in org.apache.samza.system.chooser
MessageChooser is an interface for programmatic fine-grain control over stream consumption.
MessageChooserFactory - Interface in org.apache.samza.system.chooser
Build an instance of a MessageChooser
MessageCollector - Interface in org.apache.samza.task
Used as an interface for the means of sending message envelopes to an output stream.
Metric - Interface in org.apache.samza.metrics
Metric class that allows metric visitors to visit it to get its information.
MetricsRegistry - Interface in org.apache.samza.metrics
A MetricsRegistry allows its users to create new Metrics and have those metrics wired to specific metrics systems, such as JMX, provided by MetricsReporters.
MetricsReporter - Interface in org.apache.samza.metrics
A MetricsReporter is the interface that different metrics sinks, such as JMX, implement to receive metrics from the Samza framework and Samza jobs.
MetricsReporterFactory - Interface in org.apache.samza.metrics
MetricsVisitor - Class in org.apache.samza.metrics
A MetricsVisitor can be used to process each metric in a ReadableMetricsRegistry, encapsulating the logic of what to be done with each metric in the counter and gauge methods.
MetricsVisitor() - Constructor for class org.apache.samza.metrics.MetricsVisitor
 

N

newBlockingQueue() - Method in class org.apache.samza.util.BlockingEnvelopeMap
 
newCounter(String, String) - Method in interface org.apache.samza.metrics.MetricsRegistry
Create and register a new Counter
newCounter(String, Counter) - Method in interface org.apache.samza.metrics.MetricsRegistry
Register existing Counter with this registry
newCounter(String, String) - Method in class org.apache.samza.util.NoOpMetricsRegistry
 
newCounter(String, Counter) - Method in class org.apache.samza.util.NoOpMetricsRegistry
 
newGauge(String, String, T) - Method in interface org.apache.samza.metrics.MetricsRegistry
Create and register a new Gauge
newGauge(String, Gauge<T>) - Method in interface org.apache.samza.metrics.MetricsRegistry
Register an existing Gauge
newGauge(String, String, T) - Method in class org.apache.samza.util.NoOpMetricsRegistry
 
newGauge(String, Gauge<T>) - Method in class org.apache.samza.util.NoOpMetricsRegistry
 
newTimer(String, String) - Method in interface org.apache.samza.metrics.MetricsRegistry
Create and Register a new Timer
newTimer(String, Timer) - Method in interface org.apache.samza.metrics.MetricsRegistry
Register existing Timer with this registry
newTimer(String, String) - Method in class org.apache.samza.util.NoOpMetricsRegistry
 
newTimer(String, Timer) - Method in class org.apache.samza.util.NoOpMetricsRegistry
 
next() - Method in class org.apache.samza.system.SystemStreamPartitionIterator
 
NoOpMetricsRegistry - Class in org.apache.samza.util
MetricsRegistry implementation for when no actual metrics need to be recorded but a registry is still required.
NoOpMetricsRegistry() - Constructor for class org.apache.samza.util.NoOpMetricsRegistry
 

O

onCounter(String, Counter) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistryListener
 
onGauge(String, Gauge<?>) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistryListener
 
onTimer(String, Timer) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistryListener
 
org.apache.samza - package org.apache.samza
 
org.apache.samza.checkpoint - package org.apache.samza.checkpoint
 
org.apache.samza.config - package org.apache.samza.config
 
org.apache.samza.container - package org.apache.samza.container
 
org.apache.samza.container.grouper.stream - package org.apache.samza.container.grouper.stream
 
org.apache.samza.job - package org.apache.samza.job
 
org.apache.samza.metrics - package org.apache.samza.metrics
 
org.apache.samza.serializers - package org.apache.samza.serializers
 
org.apache.samza.storage - package org.apache.samza.storage
 
org.apache.samza.system - package org.apache.samza.system
 
org.apache.samza.system.chooser - package org.apache.samza.system.chooser
 
org.apache.samza.task - package org.apache.samza.task
 
org.apache.samza.util - package org.apache.samza.util
 
OutgoingMessageEnvelope - Class in org.apache.samza.system
An OutgoingMessageEnvelope is sent to a specified SystemStream via the appropriate SystemProducer from the user's StreamTask.
OutgoingMessageEnvelope(SystemStream, String, String, Object, Object, Object) - Constructor for class org.apache.samza.system.OutgoingMessageEnvelope
Constructs a new OutgoingMessageEnvelope from specified components.
OutgoingMessageEnvelope(SystemStream, Object, Object, Object) - Constructor for class org.apache.samza.system.OutgoingMessageEnvelope
Constructs a new OutgoingMessageEnvelope from specified components.
OutgoingMessageEnvelope(SystemStream, Object, Object) - Constructor for class org.apache.samza.system.OutgoingMessageEnvelope
Constructs a new OutgoingMessageEnvelope from specified components.
OutgoingMessageEnvelope(SystemStream, Object) - Constructor for class org.apache.samza.system.OutgoingMessageEnvelope
Constructs a new OutgoingMessageEnvelope from specified components.

P

Partition - Class in org.apache.samza
A numbered, ordered partition of a stream.
Partition(int) - Constructor for class org.apache.samza.Partition
Constructs a new Samza stream partition from a specified partition number.
partition - Variable in class org.apache.samza.system.SystemStreamPartition
 
poll(Set<SystemStreamPartition>, long) - Method in interface org.apache.samza.system.SystemConsumer
Poll the SystemConsumer to get any available messages from the underlying system.
poll(Set<SystemStreamPartition>, long) - Method in class org.apache.samza.util.BlockingEnvelopeMap
Poll the SystemConsumer to get any available messages from the underlying system.
process(IncomingMessageEnvelope, MessageCollector, TaskCoordinator) - Method in interface org.apache.samza.task.StreamTask
Called once for each message that this StreamTask receives.
put(String, String) - Method in class org.apache.samza.config.Config
 
put(SystemStreamPartition, IncomingMessageEnvelope) - Method in class org.apache.samza.util.BlockingEnvelopeMap
Place a new IncomingMessageEnvelope on the queue for the specified SystemStreamPartition.
putAll(Map<? extends String, ? extends String>) - Method in class org.apache.samza.config.Config
 
putAll(SystemStreamPartition, List<IncomingMessageEnvelope>) - Method in class org.apache.samza.util.BlockingEnvelopeMap
Place a collection of IncomingMessageEnvelope on the queue for the specified SystemStreamPartition.

R

ReadableMetricsRegistry - Interface in org.apache.samza.metrics
A ReadableMetricsRegistry is a MetricsRegistry that also allows read access to the metrics for which it is responsible.
ReadableMetricsRegistryListener - Interface in org.apache.samza.metrics
 
readChangeLogPartitionMapping() - Method in interface org.apache.samza.checkpoint.CheckpointManager
Read the taskName to partition mapping that is being maintained by this CheckpointManager
readLastCheckpoint(TaskName) - Method in interface org.apache.samza.checkpoint.CheckpointManager
Returns the last recorded checkpoint for a specified taskName.
regexSubset(String) - Method in class org.apache.samza.config.Config
 
register(TaskName) - Method in interface org.apache.samza.checkpoint.CheckpointManager
Registers this manager to write checkpoints of a specific Samza stream partition.
register(String, ReadableMetricsRegistry) - Method in interface org.apache.samza.metrics.MetricsReporter
 
register(SystemStreamPartition, String) - Method in class org.apache.samza.system.chooser.BaseMessageChooser
 
register(SystemStreamPartition, String) - Method in interface org.apache.samza.system.chooser.MessageChooser
Called before start, to let the chooser know that it will be handling envelopes from the given SystemStreamPartition.
register(SystemStreamPartition, String) - Method in interface org.apache.samza.system.SystemConsumer
Register a SystemStreamPartition to this SystemConsumer.
register(String) - Method in interface org.apache.samza.system.SystemProducer
Registers this producer to send messages from a specified Samza source, such as a StreamTask.
register(SystemStreamPartition, String) - Method in class org.apache.samza.util.BlockingEnvelopeMap
Register a SystemStreamPartition to this SystemConsumer.
remove(Object) - Method in class org.apache.samza.config.Config
 
remove() - Method in class org.apache.samza.system.SystemStreamPartitionIterator
 
Reservoir - Interface in org.apache.samza.metrics
A reservoir interface to store, update and display values
restore(Iterator<IncomingMessageEnvelope>) - Method in interface org.apache.samza.storage.StorageEngine
Restore the content of this StorageEngine from the changelog.
rewrite(String, Config) - Method in interface org.apache.samza.config.ConfigRewriter
 

S

SamzaContainerContext - Class in org.apache.samza.container
A SamzaContainerContext maintains per-container information for the tasks it executes.
SamzaContainerContext(int, Config, Collection<TaskName>) - 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
 
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.
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
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
 
setConfig(Config) - Method in class org.apache.samza.job.CommandBuilder
 
setId(int) - Method in class org.apache.samza.job.CommandBuilder
 
setIsAtHead(SystemStreamPartition, boolean) - Method in class org.apache.samza.util.BlockingEnvelopeMap
 
setNoMoreMessages(SystemStreamPartition, boolean) - Method in class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
 
setStartingOffset(SystemStreamPartition, String) - Method in interface org.apache.samza.task.TaskContext
Set the starting offset for the given SystemStreamPartition.
setUrl(URL) - Method in class org.apache.samza.job.CommandBuilder
 
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
 
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
 
Snapshot - Class in org.apache.samza.metrics
A statistical snapshot of a collection of values
Snapshot(Collection<Long>) - Constructor for class org.apache.samza.metrics.Snapshot
 
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.
stop() - Method in interface org.apache.samza.checkpoint.CheckpointManager
 
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.
stream - Variable in class org.apache.samza.system.SystemStream
 
StreamJob - Interface in org.apache.samza.job
A StreamJob runs Samza StreamTasks in its specific environment.
StreamJobFactory - Interface in org.apache.samza.job
Build a StreamJob
StreamTask - Interface in org.apache.samza.task
A StreamTask is the basic class on which Samza jobs are implemented.
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
 
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
Build the SystemConsumer and SystemProducer for a particular system, as well as the accompanying SystemAdmin.
SystemProducer - Interface in org.apache.samza.system
SystemProducers are how Samza writes messages from StreamTasks to outside systems, such as messaging systems like Kafka, or file systems.
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
Aggregate object representing a both the SystemStream and Partition.
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
Iterator that wraps a SystemConsumer to iterate over the messages the consumer provides for the specified SystemStreamPartition.
SystemStreamPartitionIterator(SystemConsumer, SystemStreamPartition) - Constructor for class org.apache.samza.system.SystemStreamPartitionIterator
 
SystemStreamPartitionIterator(SystemConsumer, SystemStreamPartition, int) - Constructor for class org.apache.samza.system.SystemStreamPartitionIterator
 
SystemStreamPartitionMetadata(String, String, String) - Constructor for class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
 

T

TaskContext - Interface in org.apache.samza.task
A TaskContext provides resources about the StreamTask, particularly during initialization in an InitableTask.
TaskCoordinator - Interface in org.apache.samza.task
TaskCoordinators are provided to the process methods of StreamTask implementations to allow the user code to request actions from the Samza framework, including committing the current checkpoints to configured CheckpointManagers or shutting down the task or all tasks within a container.
TaskCoordinator.RequestScope - Enum in org.apache.samza.task
A task can make requests to the Samza framework while processing messages, such as TaskCoordinator.commit(RequestScope) and TaskCoordinator.shutdown(RequestScope).
TaskName - Class in org.apache.samza.container
A unique identifier of a set of a SystemStreamPartitions that have been grouped by a SystemStreamPartitionGrouper.
TaskName(String) - Constructor for class org.apache.samza.container.TaskName
 
taskNames - Variable in class org.apache.samza.container.SamzaContainerContext
 
timer(Timer) - Method in class org.apache.samza.metrics.MetricsVisitor
 
Timer - Class in org.apache.samza.metrics
A timer metric that stores time duration and provides Snapshot of the durations.
Timer(String) - Constructor for class org.apache.samza.metrics.Timer
Default constructor.
Timer(String, long, Clock) - Constructor for class org.apache.samza.metrics.Timer
Construct a Timer with given window size
Timer(String, Reservoir) - Constructor for class org.apache.samza.metrics.Timer
Construct a Timer with given Reservoir
toBytes(T) - Method in interface org.apache.samza.serializers.Serializer
Serializes given object to an array of bytes.
toString() - Method in class org.apache.samza.checkpoint.Checkpoint
 
toString() - Method in class org.apache.samza.config.MapConfig
 
toString() - Method in class org.apache.samza.container.TaskName
 
toString() - Method in enum org.apache.samza.job.ApplicationStatus
 
toString() - Method in class org.apache.samza.metrics.Counter
 
toString() - Method in class org.apache.samza.metrics.Gauge
 
toString() - Method in class org.apache.samza.Partition
 
toString() - Method in class org.apache.samza.system.IncomingMessageEnvelope
 
toString() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
toString() - Method in class org.apache.samza.system.SystemStream
 
toString() - Method in class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
 
toString() - Method in class org.apache.samza.system.SystemStreamMetadata
 
toString() - Method in class org.apache.samza.system.SystemStreamPartition
 

U

unlisten(ReadableMetricsRegistryListener) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
 
update(long) - Method in interface org.apache.samza.metrics.Reservoir
Update the reservoir with the new value
update(long) - Method in class org.apache.samza.metrics.SlidingTimeWindowReservoir
 
update(long) - Method in class org.apache.samza.metrics.Timer
Add the time duration
update(IncomingMessageEnvelope) - Method in interface org.apache.samza.system.chooser.MessageChooser
Notify the chooser that a new envelope is available for a processing.
url - Variable in class org.apache.samza.job.CommandBuilder
 

V

valueOf(String) - Static method in enum org.apache.samza.job.ApplicationStatus
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
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
 

W

waitForFinish(long) - Method in interface org.apache.samza.job.StreamJob
Block on this job until either it finishes or reaches its timeout value
waitForStatus(ApplicationStatus, long) - Method in interface org.apache.samza.job.StreamJob
Block on this job until either it transitions to the specified status or reaches it timeout value
window(MessageCollector, TaskCoordinator) - Method in interface org.apache.samza.task.WindowableTask
Called by TaskRunner for each implementing task at the end of every specified window.
WindowableTask - Interface in org.apache.samza.task
Add-on interface to StreamTask implementations to add code which will be run on a specified time interval (via configuration).
writeChangeLogPartitionMapping(Map<TaskName, Integer>) - Method in interface org.apache.samza.checkpoint.CheckpointManager
Write the taskName to partition mapping that is being maintained by this CheckpointManager
writeCheckpoint(TaskName, Checkpoint) - Method in interface org.apache.samza.checkpoint.CheckpointManager
Writes a checkpoint based on the current state of a Samza stream partition.
A B C D E F G H I K L M N O P R S T U V W 
Skip navigation links