- 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
-
- 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.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(Offset) - Method in class org.apache.samza.operators.data.LongOffset
-
- 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
-
- 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
-
- count(long) - Static method in class org.apache.samza.operators.triggers.Triggers
-
- 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 extends MessageEnvelope> - Class in org.apache.samza.operators.triggers
-
A
Trigger
that fires when the number of messages in the
WindowPane
reaches the specified count.
- 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
-
- createCoordinatorStream(String) - Method in interface org.apache.samza.system.SystemAdmin
-
Create a stream for the job coordinator.
- createCoordinatorStream(String) - Method in class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
-
- createInstance() - Method in interface org.apache.samza.task.AsyncStreamTaskFactory
-
- createInstance() - Method in interface org.apache.samza.task.StreamTaskFactory
-
- 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
-
- 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
.
- getAdmin(String, Config) - Method in interface org.apache.samza.system.SystemFactory
-
- getAll(KeyValueStore<K, V>, List<K>) - Static method in class org.apache.samza.storage.kv.KeyValueStore.Extension
-
Gets the values with which the specified keys
are associated.
- 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.
- 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 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
-
- getFoldFunction() - 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
-
- 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.data.IncomingSystemMessageEnvelope
-
- getKey() - Method in interface org.apache.samza.operators.data.MessageEnvelope
-
- 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
-
- 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
- getMaxOffset() - Static method in class org.apache.samza.operators.data.LongOffset
-
Helper method to get the maximum offset
- getMessage() - Method in class org.apache.samza.operators.data.IncomingSystemMessageEnvelope
-
- getMessage() - Method in interface org.apache.samza.operators.data.MessageEnvelope
-
- 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
- getMinOffset() - Static method in class org.apache.samza.operators.data.LongOffset
-
Helper method to get the minimum offset
- 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.operators.data.IncomingSystemMessageEnvelope
-
- 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
-
- getSamzaContainerContext() - Method in interface org.apache.samza.task.TaskContext
-
- 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
- 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
-
- 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
-
- 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.operators.data.IncomingSystemMessageEnvelope
-
- 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 interface org.apache.samza.task.TaskContext
-
- getTimerValues(String, String) - Method in interface org.apache.samza.metrics.MetricsAccessor
-
Get the values of a timer
- getTriggers() - Method in class org.apache.samza.operators.triggers.AnyTrigger
-
- 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.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
- getWindowId() - Method in class org.apache.samza.operators.windows.WindowKey
-
- globalWindow(BiFunction<M, WV, WV>) - Static method in class org.apache.samza.operators.windows.Windows
-
- globalWindow() - Static method in class org.apache.samza.operators.windows.Windows
-
- group(Set<SystemStreamPartition>) - Method in interface org.apache.samza.container.grouper.stream.SystemStreamPartitionGrouper
-
- 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
-
- 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
-
- setEarlyTrigger(Trigger) - 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(int) - Method in class org.apache.samza.job.CommandBuilder
-
- setIsAtHead(SystemStreamPartition, boolean) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- setLateTrigger(Trigger) - 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
-
- 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<M>) - Method in interface org.apache.samza.operators.MessageStream
-
- SinkFunction<M extends MessageEnvelope> - Interface in org.apache.samza.operators.functions
-
- 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
- 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.
- 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
-
- StreamJob - Interface in org.apache.samza.job
-
A StreamJob runs Samza
StreamTask
s in its specific environment.
- StreamJobFactory - Interface in org.apache.samza.job
-
- StreamOperatorTask - Interface in org.apache.samza.operators
-
- 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
-
- 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
-
- 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.
- 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
- validateChangelogStream(String, int) - Method in interface org.apache.samza.system.SystemAdmin
-
Validates change log stream
- validateChangelogStream(String, int) - Method in class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
-
- 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.operators.triggers.DurationCharacteristic
-
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.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.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.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.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
-