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

A

AccumulationMode - Enum in org.apache.samza.operators.windows
Specifies how a Window should process its previously emitted WindowPanes.
acquire(int) - Method in interface org.apache.samza.util.RateLimiter
Attempt to acquire the provided number of credits, blocks indefinitely until all requested credits become available.
acquire(int, long, TimeUnit) - Method in interface org.apache.samza.util.RateLimiter
Attempt to acquire the provided number of credits, blocks for up to provided amount of time for credits to become available.
acquire(Map<String, Integer>) - Method in interface org.apache.samza.util.RateLimiter
Attempt to acquire the provided number of credits for a number of tags, blocks indefinitely until all requested credits become available
acquire(Map<String, Integer>, long, TimeUnit) - Method in interface org.apache.samza.util.RateLimiter
Attempt to acquire the provided number of credits for a number of tags, blocks for up to provided amount of time for credits to become available.
add(T) - Method in class org.apache.samza.metrics.ListGauge
Add a value to the list.
afterFailure(Throwable) - Method in interface org.apache.samza.runtime.ProcessorLifecycleListener
User defined callback after a StreamProcessor is stopped with failure
afterStart() - Method in interface org.apache.samza.runtime.ProcessorLifecycleListener
User defined callback after a StreamProcessor is started
afterStop() - Method in interface org.apache.samza.runtime.ProcessorLifecycleListener
User defined callback after a StreamProcessor is stopped successfully
all() - Method in interface org.apache.samza.metadatastore.MetadataStore
Returns all the entries in this metadata store.
all() - Method in interface org.apache.samza.storage.kv.KeyValueStore
Returns an iterator for all entries in this key-value store.
any(Trigger<M>...) - Static method in class org.apache.samza.operators.triggers.Triggers
Creates a trigger that fires when any of the provided triggers fire.
AnyTrigger<M> - Class in org.apache.samza.operators.triggers
A Trigger fires as soon as any of its individual triggers has fired.
ApplicationContainerContext - Interface in org.apache.samza.context
An ApplicationContainerContext instance can be used for holding per-container runtime state and objects and managing their lifecycle.
ApplicationContainerContextFactory<T extends ApplicationContainerContext> - Interface in org.apache.samza.context
The factory for creating ApplicationContainerContext instances for a SamzaApplication during container initialization.
ApplicationDescriptor<S extends ApplicationDescriptor> - Interface in org.apache.samza.application.descriptors
An ApplicationDescriptor contains the description of inputs, outputs, state, configuration and the processing logic for a SamzaApplication.
ApplicationRunner - Interface in org.apache.samza.runtime
The primary means of managing execution of the SamzaApplication at runtime.
ApplicationRunners - Class in org.apache.samza.runtime
Creates ApplicationRunner instances based on configuration and user-implemented SamzaApplication
ApplicationStatus - Class in org.apache.samza.job
Status of a StreamJob during and after its run.
ApplicationStatus.StatusCode - Enum in org.apache.samza.job
 
ApplicationTaskContext - Interface in org.apache.samza.context
An ApplicationTaskContext instance can be used for holding per-task runtime state and objects and managing their lifecycle in an SamzaApplication
ApplicationTaskContextFactory<T extends ApplicationTaskContext> - Interface in org.apache.samza.context
The factory for creating ApplicationTaskContext instances for a SamzaApplicationduring task initialization.
apply(M) - Method in interface org.apache.samza.operators.functions.FilterFunction
Returns a boolean indicating whether this message should be retained or filtered out.
apply(M) - Method in interface org.apache.samza.operators.functions.FlatMapFunction
Transforms the provided message into a collection of 0 or more messages.
apply(M, WV) - Method in interface org.apache.samza.operators.functions.FoldLeftFunction
Incrementally updates the aggregated value as messages are added.
apply(M, JM) - Method in interface org.apache.samza.operators.functions.JoinFunction
Joins the provided messages and returns the joined message.
apply(M) - Method in interface org.apache.samza.operators.functions.MapFunction
Transforms the provided message into another message.
apply(M, MessageCollector, TaskCoordinator) - Method in interface org.apache.samza.operators.functions.SinkFunction
Allows sending the provided message to an output SystemStream using the provided MessageCollector.
apply(M, R) - Method in interface org.apache.samza.operators.functions.StreamTableJoinFunction
Joins the provided messages and table record, returns the joined message.
apply(IncomingMessageEnvelope) - Method in interface org.apache.samza.system.descriptors.InputTransformer
Transforms the provided IncomingMessageEnvelope with deserialized key and message into another message which is delivered to the MessageStream.
apply(StreamApplicationDescriptor, InputDescriptor) - Method in interface org.apache.samza.system.descriptors.StreamExpander
Expands the provided InputDescriptor to a sub-DAG of one or more operators on the StreamApplicationDescriptor, and returns a new MessageStream with the combined results.
AsyncStreamTask - Interface in org.apache.samza.task
An AsyncStreamTask is the basic class to support multithreading execution in Samza container.
AsyncStreamTaskFactory - Interface in org.apache.samza.task
Build AsyncStreamTask instances.

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
 
beforeStart() - Method in interface org.apache.samza.runtime.ProcessorLifecycleListener
User defined initialization before a StreamProcessor is started
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(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
 
BlockingEnvelopeMap.BufferSizeGauge - Class in org.apache.samza.util
 
BlockingEnvelopeMapMetrics(String, MetricsRegistry) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap.BlockingEnvelopeMapMetrics
 
broadcast(Serde<M>, String) - Method in interface org.apache.samza.operators.MessageStream
Broadcasts messages in this MessageStream to all instances of its downstream operators..
BufferGauge(SystemStreamPartition, String) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap.BufferGauge
 
BufferSizeGauge(SystemStreamPartition, String) - Constructor for class org.apache.samza.util.BlockingEnvelopeMap.BufferSizeGauge
 
build() - Method in class org.apache.samza.storage.StoreProperties.StorePropertiesBuilder
 
buildCommand() - Method in class org.apache.samza.job.CommandBuilder
 
buildEndOfStreamEnvelope(SystemStreamPartition) - Static method in class org.apache.samza.system.IncomingMessageEnvelope
This method is deprecated in favor of WatermarkManager.buildEndOfStreamEnvelope(SystemStreamPartition ssp).
buildEnvironment() - Method in class org.apache.samza.job.CommandBuilder
 
buildWatermarkEnvelope(SystemStreamPartition, long) - Static method in class org.apache.samza.system.IncomingMessageEnvelope
 
ByteBufferSerde - Class in org.apache.samza.serializers
A serializer for ByteBuffers.
ByteBufferSerde() - Constructor for class org.apache.samza.serializers.ByteBufferSerde
 
ByteBufferSerdeFactory - Class in org.apache.samza.serializers
 
ByteBufferSerdeFactory() - Constructor for class org.apache.samza.serializers.ByteBufferSerdeFactory
 
ByteSerde - Class in org.apache.samza.serializers
A serializer for bytes that is effectively a pass-through, but can be useful for binary messages.
ByteSerde() - Constructor for class org.apache.samza.serializers.ByteSerde
 
ByteSerdeFactory - Class in org.apache.samza.serializers
 
ByteSerdeFactory() - Constructor for class org.apache.samza.serializers.ByteSerdeFactory
 

C

CallbackScheduler - Interface in org.apache.samza.scheduler
Provides a way for applications to register some logic to be executed at a future time.
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 entire 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
Deprecated.
close() - Method in interface org.apache.samza.metadatastore.MetadataStore
Closes the metadata store, if applicable, relinquishing all the underlying resources and connections.
close() - Method in interface org.apache.samza.operators.functions.ClosableFunction
Frees any resource acquired by the operators in InitableFunction
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.KeyValueSnapshot
Closes this snapshot releasing any associated resources.
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.table.descriptors.TableProvider
Shutdown the underlying table
close() - Method in interface org.apache.samza.table.ReadableTable
Close the table and release any resources acquired
close() - Method in interface org.apache.samza.task.ClosableTask
Deprecated.
 
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(TaskModel) - Method in class org.apache.samza.job.model.TaskModel
 
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.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.
ContainerContext - Interface in org.apache.samza.context
The framework-provided context for the current container.
ContainerModel - Class in org.apache.samza.job.model
This contains metadata about a Samza container, such as which tasks a Samza container should process.
ContainerModel(String, Map<TaskName, TaskModel>) - Constructor for class org.apache.samza.job.model.ContainerModel
 
containsKey(Object) - Method in class org.apache.samza.config.MapConfig
 
containsValue(Object) - Method in class org.apache.samza.config.MapConfig
 
Context - Interface in org.apache.samza.context
A holder for all framework and application defined contexts at runtime.
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.
create(JobContext, ContainerContext) - Method in interface org.apache.samza.context.ApplicationContainerContextFactory
Creates an instance of the application-defined ApplicationContainerContext.
create(JobContext, ContainerContext, TaskContext, ApplicationContainerContext) - Method in interface org.apache.samza.context.ApplicationTaskContextFactory
Creates an instance of the application-defined ApplicationTaskContext.
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(ProcessorContext, Config) - Method in interface org.apache.samza.runtime.ProcessorLifecycleListenerFactory
Create an instance of ProcessorLifecycleListener for the StreamProcessor
createInstance() - Method in interface org.apache.samza.task.TaskFactory
Create instance of task
createResources() - Method in interface org.apache.samza.checkpoint.CheckpointManager
Creates checkpoint stream.
createStream(StreamSpec) - Method in interface org.apache.samza.system.SystemAdmin
Create a stream described by the spec.
createStreamAppenderStreamSpec(String, String, int) - Static method in class org.apache.samza.system.StreamSpec
 
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
 
delete(byte[]) - Method in interface org.apache.samza.metadatastore.MetadataStore
Deletes the mapping for the specified key from this metadata store (if such mapping exists).
delete(K) - Method in interface org.apache.samza.operators.Scheduler
Delete the scheduled callback for the provided key.
delete(K) - Method in interface org.apache.samza.storage.kv.KeyValueStore
Deletes the mapping for the specified key from this key-value store (if such mapping exists).
delete(K) - Method in interface org.apache.samza.table.ReadWriteTable
Deletes the mapping for the specified key from this table (if such mapping exists).
deleteAll(List<K>) - Method in interface org.apache.samza.storage.kv.KeyValueStore
Deletes the mappings for the specified keys from this key-value store (if such mappings exist).
deleteAll(List<K>) - Method in interface org.apache.samza.table.ReadWriteTable
Deletes the mappings for the specified keys from this table.
deleteAllAsync(List<K>) - Method in interface org.apache.samza.table.ReadWriteTable
Asynchronously deletes the mappings for the specified keys from this table.
deleteAsync(K) - Method in interface org.apache.samza.table.ReadWriteTable
Asynchronously deletes the mapping for the specified key from this table (if such mapping exists).
deleteCallback(K) - Method in interface org.apache.samza.scheduler.CallbackScheduler
Delete the scheduled callback for the key.
deleteMessages(Map<SystemStreamPartition, String>) - Method in interface org.apache.samza.system.SystemAdmin
Delete records up to (and including) the provided ssp offsets for all system stream partitions specified in the map
describe(S) - Method in interface org.apache.samza.application.SamzaApplication
Describes the inputs, outputs, state, configuration and processing logic using the provided appDescriptor.
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.
DoubleSerde - Class in org.apache.samza.serializers
A serializer for doubles
DoubleSerde() - Constructor for class org.apache.samza.serializers.DoubleSerde
 
DoubleSerdeFactory - Class in org.apache.samza.serializers
 
DoubleSerdeFactory() - Constructor for class org.apache.samza.serializers.DoubleSerdeFactory
 
DurationCharacteristic - Enum in org.apache.samza.operators.triggers
Indicates whether the associated time duration is in event time or processing time.

E

END_OF_STREAM_OFFSET - Static variable in class org.apache.samza.system.IncomingMessageEnvelope
 
EndOfStreamListenerTask - Interface in org.apache.samza.task
The EndOfStreamListenerTask augments StreamTask allowing the method implementor to specify code to be executed when the 'end-of-stream' is reached for all input SSPs.
EndOfStreamMessage - Class in org.apache.samza.system
The EndOfStreamMessage is a control message that is sent out to next stage once the task has consumed to the end of a bounded stream.
EndOfStreamMessage() - Constructor for class org.apache.samza.system.EndOfStreamMessage
 
EndOfStreamMessage(String) - Constructor for class org.apache.samza.system.EndOfStreamMessage
 
Entry<K,V> - Class in org.apache.samza.storage.kv
A key and value.
Entry(K, V) - Constructor for class org.apache.samza.storage.kv.Entry
 
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.job.ApplicationStatus
 
equals(Object) - Method in class org.apache.samza.job.model.ContainerModel
 
equals(Object) - Method in class org.apache.samza.job.model.TaskModel
 
equals(Object) - Method in class org.apache.samza.operators.windows.WindowKey
 
equals(Object) - Method in class org.apache.samza.Partition
 
equals(Object) - Method in class org.apache.samza.runtime.LocationId
 
equals(Object) - Method in class org.apache.samza.sql.SamzaSqlRelRecord
 
equals(Object) - Method in class org.apache.samza.system.ControlMessage
 
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.StreamSpec
 
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
 
equals(Object) - Method in class org.apache.samza.system.WatermarkMessage
 
equals(Object) - Method in class org.apache.samza.table.TableSpec
 
equals(Object) - Method in class org.apache.samza.util.TimestampedValue
 
execute(Object...) - Method in interface org.apache.samza.sql.udfs.ScalarUdf
Actual implementation of the udf function
ExpandingInputDescriptorProvider<StreamExpanderType> - Interface in org.apache.samza.system.descriptors
Interface for advanced SystemDescriptors that constrain the type of returned InputDescriptors to their own StreamExpander function result types.
ExtendedSystemAdmin - Interface in org.apache.samza.system
Interface extends the more generic SystemAdmin interface TODO: Merge this interface method with SystemAdmin when we upgrade to JDK 1.8

F

failure(Throwable) - Method in interface org.apache.samza.task.TaskCallback
Invoke when the asynchronous process failed with an error.
filter(FilterFunction<? super M>) - Method in interface org.apache.samza.operators.MessageStream
Applies the provided function to messages in this MessageStream and returns the filtered MessageStream.
filter(Set<SystemStreamPartition>, Config) - Method in interface org.apache.samza.system.SystemStreamPartitionMatcher
 
FilterFunction<M> - Interface in org.apache.samza.operators.functions
Specifies whether a message should be retained for further processing.
FiringType - Enum in org.apache.samza.operators.triggers
The type of the Trigger firing.
flatMap(FlatMapFunction<? super M, ? extends OM>) - Method in interface org.apache.samza.operators.MessageStream
Applies the provided 1:n function to transform a message in this MessageStream to n messages in the transformed MessageStream
FlatMapFunction<M,OM> - Interface in org.apache.samza.operators.functions
Transforms an input message into a collection of 0 or more messages, possibly of a different type.
flush() - Method in interface org.apache.samza.metadatastore.MetadataStore
Flushes the metadata store, if applicable.
flush() - Method in interface org.apache.samza.storage.kv.KeyValueStore
Flushes this key-value store, if applicable.
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.
flush() - Method in interface org.apache.samza.table.ReadWriteTable
Flushes the underlying store of this table, if applicable.
FoldLeftFunction<M,WV> - Interface in org.apache.samza.operators.functions
Incrementally updates the aggregated value as messages are added.
fromBytes(byte[]) - Method in class org.apache.samza.serializers.ByteBufferSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.ByteSerde
 
fromBytes(byte[]) - Method in interface org.apache.samza.serializers.Deserializer
Deserializes given serialized object from an array of bytes to its original form.
fromBytes(byte[]) - Method in class org.apache.samza.serializers.DoubleSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.IntegerSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.JsonSerdeV2
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.KVSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.LongSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.NoOpSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.SerializableSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.StringSerde
 
fromBytes(byte[]) - Method in class org.apache.samza.serializers.UUIDSerde
 

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
 
generateConfig(Config, Map<String, String>) - Method in interface org.apache.samza.table.descriptors.TableProvider
Generate any configuration for this table, the generated configuration is used by Samza container to construct this table and any components necessary.
generateProcessorId(Config) - Method in interface org.apache.samza.runtime.ProcessorIdGenerator
Generates a String representation to identify a single instance of StreamProcessor.
GenericInputDescriptor<StreamMessageType> - Class in org.apache.samza.system.descriptors
A GenericInputDescriptor can be used for specifying Samza and system-specific properties of input streams.
GenericOutputDescriptor<StreamMessageType> - Class in org.apache.samza.system.descriptors
A GenericOutputDescriptor can be used for specifying Samza and system-specific properties of output streams.
GenericSystemDescriptor - Class in org.apache.samza.system.descriptors
A GenericSystemDescriptor can be used for specifying Samza and system-specific properties of an input/output system.
GenericSystemDescriptor(String, String) - Constructor for class org.apache.samza.system.descriptors.GenericSystemDescriptor
Constructs a GenericSystemDescriptor instance with no system level serde.
get(String, String) - Method in class org.apache.samza.config.Config
 
get(Object) - Method in class org.apache.samza.config.MapConfig
 
get(byte[]) - Method in interface org.apache.samza.metadatastore.MetadataStore
Gets the value associated with the specified key.
get() - Method in interface org.apache.samza.operators.functions.SupplierFunction
Returns a value of type T
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
 
get(K) - Method in interface org.apache.samza.table.ReadableTable
Gets the value associated with the specified key.
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.
getAll(List<K>) - Method in interface org.apache.samza.table.ReadableTable
Gets the values with which the specified keys are associated.
getAllAsync(List<K>) - Method in interface org.apache.samza.table.ReadableTable
Asynchronously gets the values with which the specified keys are associated.
getApplicationContainerContext() - Method in interface org.apache.samza.context.Context
Gets the application-defined context for the current container.
getApplicationRunner(SamzaApplication, Config) - Static method in class org.apache.samza.runtime.ApplicationRunners
Get the ApplicationRunner that runs the userApp
getApplicationTaskContext() - Method in interface org.apache.samza.context.Context
Gets the application-defined task context for the current task.
getAsync(K) - Method in interface org.apache.samza.table.ReadableTable
Asynchronously gets the value associated with the specified key.
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
 
getCallbackScheduler() - Method in interface org.apache.samza.context.TaskContext
Gets the CallbackScheduler for this task, which can be used to schedule a callback to be executed at a future time.
getChangelogPartition() - Method in class org.apache.samza.job.model.TaskModel
Returns the Partition used for all changelogs for this task.
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() - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
Get the configuration for the application.
getConfig(URI) - Method in interface org.apache.samza.config.ConfigFactory
Build a specific Config.
getConfig() - Method in interface org.apache.samza.context.JobContext
Gets the final configuration for this job.
getConfig() - Method in class org.apache.samza.system.StreamSpec
 
getConfig() - Method in class org.apache.samza.table.TableSpec
Get implementation configuration for the table
getConsumer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
 
getContainerContext() - Method in interface org.apache.samza.context.Context
Gets the framework-provided context for the current container.
getContainerMetricsRegistry() - Method in interface org.apache.samza.context.ContainerContext
Gets the MetricsRegistry for this container, which can be used to register metrics that are reported per container.
getContainerModel() - Method in interface org.apache.samza.context.ContainerContext
Gets the ContainerModel for this container, which contains this container's id and its TaskModel.
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
 
getExpander() - Method in class org.apache.samza.system.descriptors.SystemDescriptor
 
getField(String) - Method in class org.apache.samza.sql.SamzaSqlRelRecord
Get the value of the field corresponding to the field name.
getFieldNames() - Method in class org.apache.samza.sql.SamzaSqlRelRecord
Get the field names of all the columns in the relational message.
getFieldValues() - Method in class org.apache.samza.sql.SamzaSqlRelRecord
Get the field values of all the columns in the relational message.
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.job.model.ContainerModel
Returns the id for the container associated with this model.
getId() - Method in class org.apache.samza.runtime.LocationId
 
getId() - Method in class org.apache.samza.system.StreamSpec
 
getId() - Method in class org.apache.samza.table.TableSpec
Get the Id of the table
getInitializer() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
 
getInputDescriptor(String, Serde) - Method in interface org.apache.samza.system.descriptors.ExpandingInputDescriptorProvider
Gets a InputDescriptor for an input stream on this system.
getInputDescriptor(String, Serde<StreamMessageType>) - Method in class org.apache.samza.system.descriptors.GenericSystemDescriptor
 
getInputDescriptor(String, Serde<StreamMessageType>) - Method in interface org.apache.samza.system.descriptors.SimpleInputDescriptorProvider
Gets an InputDescriptor for an input stream on this system.
getInputDescriptor(String, Serde) - Method in interface org.apache.samza.system.descriptors.TransformingInputDescriptorProvider
Gets a InputDescriptor for an input stream on this system.
getInputStream(InputDescriptor<M, ?>) - Method in interface org.apache.samza.application.descriptors.StreamApplicationDescriptor
Gets the input MessageStream corresponding to the inputDescriptor.
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
 
getJobContext() - Method in interface org.apache.samza.context.Context
Gets the framework-provided context for the job.
getJobId() - Method in interface org.apache.samza.context.JobContext
Gets the id for this job.
getJobName() - Method in interface org.apache.samza.context.JobContext
Gets the name of the job.
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
 
getLocationId() - Method in interface org.apache.samza.runtime.LocationIdProvider
 
getLocationIdProvider(Config) - Method in interface org.apache.samza.runtime.LocationIdProviderFactory
 
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
 
getMessageKey(M) - Method in interface org.apache.samza.operators.functions.StreamTableJoinFunction
Retrieve the join key from incoming messages
getMessageSerializerName() - Method in class org.apache.samza.system.OutgoingMessageEnvelope
 
getMessagesSizeInQueue(SystemStreamPartition) - Method in class org.apache.samza.util.BlockingEnvelopeMap
 
getMetadataStore(String, Config, MetricsRegistry) - Method in interface org.apache.samza.metadatastore.MetadataStoreFactory
 
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.ListGauge
Get the name assigned to this ListGauge
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
Deprecated.
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
 
getOutputDescriptor(String, Serde<StreamMessageType>) - Method in class org.apache.samza.system.descriptors.GenericSystemDescriptor
 
getOutputDescriptor(String, Serde<StreamMessageType>) - Method in interface org.apache.samza.system.descriptors.OutputDescriptorProvider
Gets an OutputDescriptor representing an output stream on this system that uses the provided stream specific serde instead of the default system serde.
getOutputStream(OutputDescriptor<M, ?>) - Method in interface org.apache.samza.application.descriptors.StreamApplicationDescriptor
Gets the OutputStream corresponding to the outputDescriptor.
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.descriptors.StreamDescriptor
 
getPhysicalName() - Method in class org.apache.samza.system.StreamSpec
 
getProducer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
 
getRecordKey(R) - Method in interface org.apache.samza.operators.functions.StreamTableJoinFunction
Retrieve the join key from table record
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
 
getSerde() - Method in class org.apache.samza.system.descriptors.StreamDescriptor
 
getSerde() - Method in class org.apache.samza.table.TableSpec
Get the serde
getShort(String, short) - Method in class org.apache.samza.config.Config
 
getShort(String) - Method in class org.apache.samza.config.Config
 
getSideInputs() - Method in class org.apache.samza.table.TableSpec
Get the list of side inputs for the table.
getSideInputsProcessor(Config, MetricsRegistry) - Method in interface org.apache.samza.storage.SideInputsProcessorFactory
Creates a new instance of a SideInputsProcessor.
getSideInputsProcessor() - Method in class org.apache.samza.table.TableSpec
Get the SideInputsProcessor associated with the table.
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
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
getSSPMetadata(Set<SystemStreamPartition>) - Method in interface org.apache.samza.system.SystemAdmin
Fetch metadata from a system for a set of SSPs.
getStatus() - Method in interface org.apache.samza.job.StreamJob
Get current ApplicationStatus of the job
getStatusCode() - Method in class org.apache.samza.job.ApplicationStatus
 
getStorageEngine(String, File, Serde<K>, Serde<V>, MessageCollector, MetricsRegistry, SystemStreamPartition, JobContext, ContainerContext) - Method in interface org.apache.samza.storage.StorageEngineFactory
Create an instance of the given storage engine.
getStore(String) - Method in interface org.apache.samza.context.TaskContext
Gets the KeyValueStore associated with storeName for this task.
getStoreProperties() - Method in interface org.apache.samza.storage.StorageEngine
Get store properties
getStream() - Method in class org.apache.samza.system.SystemStream
 
getStreamId() - Method in class org.apache.samza.system.descriptors.StreamDescriptor
 
getStreamName() - Method in class org.apache.samza.system.SystemStreamMetadata
 
getSum() - Method in class org.apache.samza.metrics.Snapshot
Get the sum of values in the collection
getSupportedTags() - Method in interface org.apache.samza.util.RateLimiter
Get the entire set of tags for which we have configured credits for rate limiting.
getSystem() - Method in class org.apache.samza.system.SystemStream
 
getSystemDescriptor() - Method in class org.apache.samza.system.descriptors.StreamDescriptor
 
getSystemName() - Method in class org.apache.samza.system.descriptors.StreamDescriptor
 
getSystemName() - Method in class org.apache.samza.system.descriptors.SystemDescriptor
 
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 class org.apache.samza.job.model.TaskModel
Returns the SystemStreamPartitions that this task is responsible for consuming.
getTable(TableDescriptor<K, V, ?>) - Method in interface org.apache.samza.application.descriptors.StreamApplicationDescriptor
Gets the Table corresponding to the TableDescriptor.
getTable(String) - Method in interface org.apache.samza.context.TaskContext
Gets the Table corresponding to the tableId for this task.
getTable() - Method in interface org.apache.samza.table.descriptors.TableProvider
Get an instance of the table for read/write operations
getTableId() - Method in interface org.apache.samza.table.descriptors.TableDescriptor
Get the id of the table
getTableProvider(TableSpec) - Method in interface org.apache.samza.table.descriptors.TableProviderFactory
Constructs an instances of the table provider based on a given table spec
getTableProviderFactoryClassName() - Method in class org.apache.samza.table.TableSpec
Get the class name of the table provider factory
getTaskContext() - Method in interface org.apache.samza.context.Context
Gets the framework-provided context for the current task.
getTaskMetricsRegistry() - Method in interface org.apache.samza.context.TaskContext
Gets the MetricsRegistry for this task, which can be used to register metrics that are reported per task.
getTaskModel() - Method in interface org.apache.samza.context.TaskContext
Gets the TaskModel for this task, which contains this task's name and its SystemStreamPartitions.
getTaskName() - Method in class org.apache.samza.container.TaskName
 
getTaskName() - Method in class org.apache.samza.job.model.TaskModel
Returns the name of the task.
getTaskName() - Method in class org.apache.samza.system.ControlMessage
 
getTasks() - Method in class org.apache.samza.job.model.ContainerModel
Returns a map for all tasks in this container.
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.IncomingMessageEnvelope
 
getTimestamp() - Method in class org.apache.samza.system.WatermarkMessage
 
getTimestamp() - Method in class org.apache.samza.util.TimestampedValue
 
getTransformer() - Method in class org.apache.samza.system.descriptors.InputDescriptor
 
getTransformer() - Method in class org.apache.samza.system.descriptors.SystemDescriptor
 
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
 
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
 
getValue() - Method in class org.apache.samza.util.TimestampedValue
 
getValues() - Method in class org.apache.samza.metrics.ListGauge
Get the Collection of values currently in the list.
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
 

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.job.ApplicationStatus
 
hashCode() - Method in class org.apache.samza.job.model.ContainerModel
 
hashCode() - Method in class org.apache.samza.job.model.TaskModel
 
hashCode() - Method in class org.apache.samza.operators.windows.WindowKey
 
hashCode() - Method in class org.apache.samza.Partition
 
hashCode() - Method in class org.apache.samza.runtime.LocationId
 
hashCode() - Method in class org.apache.samza.sql.SamzaSqlRelRecord
 
hashCode() - Method in class org.apache.samza.system.ControlMessage
 
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.StreamSpec
 
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
 
hashCode() - Method in class org.apache.samza.system.WatermarkMessage
 
hashCode() - Method in class org.apache.samza.table.TableSpec
 
hashCode() - Method in class org.apache.samza.util.TimestampedValue
 
hasNext() - Method in class org.apache.samza.system.SystemStreamPartitionIterator
 

I

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() - Method in interface org.apache.samza.metadatastore.MetadataStore
Initializes the metadata store, if applicable, setting up the underlying resources and connections to the store endpoints.
init(Config) - Method in interface org.apache.samza.metrics.MetricsValidator
Initialize with config.
init(Context) - 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(Context) - Method in interface org.apache.samza.table.descriptors.TableProvider
Initialize TableProvider with container and task context
init(Context) - Method in interface org.apache.samza.table.ReadableTable
Initializes the table during container initialization.
init(Context) - Method in interface org.apache.samza.task.InitableTask
Called by TaskRunner each time an implementing task is created.
init(Context) - Method in interface org.apache.samza.util.RateLimiter
Initialize this rate limiter, this method should be called during container initialization.
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
 
InputDescriptor<StreamMessageType,SubClass extends InputDescriptor<StreamMessageType,SubClass>> - Class in org.apache.samza.system.descriptors
An InputDescriptor can be used for specifying Samza and system-specific properties of input streams.
InputDescriptor(String, Serde, SystemDescriptor, InputTransformer) - Constructor for class org.apache.samza.system.descriptors.InputDescriptor
Constructs an InputDescriptor instance.
InputTransformer<OM> - Interface in org.apache.samza.system.descriptors
Transforms an IncomingMessageEnvelope with deserialized key and message to a message of type OM which is delivered to the MessageStream.
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.descriptors.InputDescriptor
If set, this stream will be considered a bounded stream.
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
iterator() - Method in interface org.apache.samza.storage.kv.KeyValueSnapshot
Creates a new iterator for this snapshot.

J

JobContext - Interface in org.apache.samza.context
The framework-provided context for the job.
join(MessageStream<OM>, JoinFunction<? extends K, ? super M, ? super OM, ? extends JM>, Serde<K>, Serde<M>, Serde<OM>, Duration, String) - Method in interface org.apache.samza.operators.MessageStream
Joins this MessageStream with another MessageStream using the provided pairwise JoinFunction.
join(Table<R>, StreamTableJoinFunction<? extends K, ? super M, ? super R, ? extends JM>) - Method in interface org.apache.samza.operators.MessageStream
Joins this MessageStream with another Table using the provided pairwise StreamTableJoinFunction.
JoinFunction<K,M,JM,RM> - Interface in org.apache.samza.operators.functions
Joins incoming messages in two streams by key.
JsonSerdeV2<T> - Class in org.apache.samza.serializers
A serializer for UTF-8 encoded JSON strings.
JsonSerdeV2() - Constructor for class org.apache.samza.serializers.JsonSerdeV2
Constructs a JsonSerdeV2 that returns a LinkedHashMap<String, Object< upon deserialization.
JsonSerdeV2(Class<T>) - Constructor for class org.apache.samza.serializers.JsonSerdeV2
Constructs a JsonSerdeV2 that (de)serializes POJOs of class clazz.
JsonSerdeV2Factory - Class in org.apache.samza.serializers
 
JsonSerdeV2Factory() - Constructor for class org.apache.samza.serializers.JsonSerdeV2Factory
 

K

key - Variable in class org.apache.samza.operators.KV
 
keyedSessionWindow(MapFunction<? super M, ? extends K>, Duration, SupplierFunction<? extends WV>, FoldLeftFunction<? super M, WV>, Serde<K>, Serde<WV>) - Static method in class org.apache.samza.operators.windows.Windows
Creates a Window that groups incoming messages into sessions per-key based on the provided sessionGap and applies the provided fold function to them.
keyedSessionWindow(MapFunction<? super M, ? extends K>, Duration, Serde<K>, Serde<M>) - Static method in class org.apache.samza.operators.windows.Windows
Creates a Window that groups incoming messages into sessions per-key based on the provided sessionGap.
keyedTumblingWindow(MapFunction<? super M, ? extends K>, Duration, SupplierFunction<? extends WV>, FoldLeftFunction<? super M, WV>, Serde<K>, Serde<WV>) - Static method in class org.apache.samza.operators.windows.Windows
Creates a Window that groups incoming messages into fixed-size, non-overlapping processing time based windows based on the provided keyFn and applies the provided fold function to them.
keyedTumblingWindow(MapFunction<M, K>, Duration, Serde<K>, Serde<M>) - Static method in class org.apache.samza.operators.windows.Windows
Creates a Window that groups incoming messages into fixed-size, non-overlapping processing time based windows using the provided keyFn.
keySet() - Method in class org.apache.samza.config.MapConfig
 
KeyValueIterator<K,V> - Interface in org.apache.samza.storage.kv
 
KeyValueSnapshot<K,V> - Interface in org.apache.samza.storage.kv
An immutable view of the KeyValueStore at a point-in-time.
KeyValueStore<K,V> - Interface in org.apache.samza.storage.kv
A key-value store that supports put, get, delete, and range queries.
kill() - Method in interface org.apache.samza.job.StreamJob
Kill this job immediately.
kill() - Method in interface org.apache.samza.runtime.ApplicationRunner
Kill the Samza jobs represented by SamzaApplication It is non-blocking so it doesn't wait for the application stopping.
KV<K,V> - Class in org.apache.samza.operators
A key and value pair.
KV(K, V) - Constructor for class org.apache.samza.operators.KV
 
KVSerde<K,V> - Class in org.apache.samza.serializers
A serializer that serves one of the following two purposes: When used for input/output streams, serves as an indication to the framework that messages are keyed and should be deserialized as K-V pairs. When used for a key or value of type KV, serializes the key and value pair using the provided serdes.
KVSerde(Serde<K>, Serde<V>) - Constructor for class org.apache.samza.serializers.KVSerde
 

L

listen(ReadableMetricsRegistryListener) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
 
ListGauge<T> - Class in org.apache.samza.metrics
A ListGauge is a Metric that buffers multiple instances of a type T in a list.
ListGauge(String, int, Duration) - Constructor for class org.apache.samza.metrics.ListGauge
Create a new ListGauge that auto evicts based on the given maxNumberOfItems, maxStaleness, and period parameters.
ListGauge(String) - Constructor for class org.apache.samza.metrics.ListGauge
Create a new ListGauge that auto evicts upto a max of 100 items and a max-staleness of 60 minutes.
listGauge(ListGauge<T>) - Method in class org.apache.samza.metrics.MetricsVisitor
 
LocationId - Class in org.apache.samza.runtime
Represents the physical execution environment of the StreamProcessor.
LocationId(String) - Constructor for class org.apache.samza.runtime.LocationId
 
LocationIdProvider - Interface in org.apache.samza.runtime
Generates LocationId that uniquely identifies the execution environment of a stream processor.
LocationIdProviderFactory - Interface in org.apache.samza.runtime
Builds the LocationIdProvider.
LongSerde - Class in org.apache.samza.serializers
A serializer for longs
LongSerde() - Constructor for class org.apache.samza.serializers.LongSerde
 
LongSerdeFactory - Class in org.apache.samza.serializers
 
LongSerdeFactory() - Constructor for class org.apache.samza.serializers.LongSerdeFactory
 

M

map(MapFunction<? super M, ? extends OM>) - Method in interface org.apache.samza.operators.MessageStream
Applies the provided 1:1 function to messages in this MessageStream and returns the transformed MessageStream.
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
 
MapConfig(Map<String, String>...) - Constructor for class org.apache.samza.config.MapConfig
 
MapFunction<M,OM> - Interface in org.apache.samza.operators.functions
Transforms an input message into another message, possibly of a different type.
merge(Collection<? extends MessageStream<? extends M>>) - Method in interface org.apache.samza.operators.MessageStream
Merges all otherStreams with this MessageStream.
mergeAll(Collection<? extends MessageStream<? extends T>>) - Static method in interface org.apache.samza.operators.MessageStream
Merges all streams.
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.
MessageStream<M> - Interface in org.apache.samza.operators
A stream of messages that can be transformed into another MessageStream.
MessageType - Enum in org.apache.samza.system
The type of the intermediate stream message.
MetadataStore - Interface in org.apache.samza.metadatastore
Store abstraction responsible for managing the metadata of a Samza job.
MetadataStoreFactory - Interface in org.apache.samza.metadatastore
Builds the MetadataStore based upon the provided namespace, Config and MetricsRegistry.
Metric - Interface in org.apache.samza.metrics
Metric class that allows metric visitors to visit it to get its information.
MetricsAccessor - Interface in org.apache.samza.metrics
A MetricsAccessor allows users to retrieve metric values, based on group name and metric name, though specific metrics system, such as JMX.
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
MetricsValidationFailureException - Exception in org.apache.samza.metrics
Thrown when the metrics validation fails.
MetricsValidationFailureException(String) - Constructor for exception org.apache.samza.metrics.MetricsValidationFailureException
 
MetricsValidationFailureException(String, Throwable) - Constructor for exception org.apache.samza.metrics.MetricsValidationFailureException
 
MetricsValidator - Interface in org.apache.samza.metrics
A MetricsValidator reads the job's metrics values by using the MetricsAccessor, and validate them.
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

New - Static variable in class org.apache.samza.job.ApplicationStatus
 
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
 
newListGauge(String, ListGauge<T>) - Method in interface org.apache.samza.metrics.MetricsRegistry
Register a ListGauge
newListGauge(String, ListGauge<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
 
NoOpSerde<T> - Class in org.apache.samza.serializers
A marker serde class to indicate that messages should not be serialized or deserialized.
NoOpSerde() - Constructor for class org.apache.samza.serializers.NoOpSerde
 

O

of(K, V) - Static method in class org.apache.samza.operators.KV
 
of(Class<T>) - Static method in class org.apache.samza.serializers.JsonSerdeV2
 
of(Serde<K>, Serde<V>) - Static method in class org.apache.samza.serializers.KVSerde
 
of(Object) - Static method in enum org.apache.samza.system.MessageType
Returns the MessageType of a particular intermediate stream message.
offsetComparator(String, String) - Method in interface org.apache.samza.system.SystemAdmin
Compare the two offsets.
offsetComparator(String, String) - Method in class org.apache.samza.util.SinglePartitionWithoutOffsetsSystemAdmin
 
onCallback(K, long) - Method in interface org.apache.samza.operators.functions.ScheduledFunction
Returns the output from the scheduling logic corresponding to the key that was triggered.
onCallback(K, MessageCollector, TaskCoordinator) - Method in interface org.apache.samza.scheduler.ScheduledCallback
Invoked when the corresponding schedule time is reached.
onCheckpoint(Map<SystemStreamPartition, String>) - Method in interface org.apache.samza.checkpoint.CheckpointListener
 
onCounter(String, Counter) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistryListener
 
onEndOfStream(MessageCollector, TaskCoordinator) - Method in interface org.apache.samza.task.EndOfStreamListenerTask
Guaranteed to be invoked when all SSPs processed by this task have reached their end-of-stream.
onGauge(String, Gauge<?>) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistryListener
 
onListGauge(String, ListGauge<?>) - 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.annotation - package org.apache.samza.annotation
 
org.apache.samza.application - package org.apache.samza.application
 
org.apache.samza.application.descriptors - package org.apache.samza.application.descriptors
 
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.context - package org.apache.samza.context
 
org.apache.samza.job - package org.apache.samza.job
 
org.apache.samza.job.model - package org.apache.samza.job.model
 
org.apache.samza.metadatastore - package org.apache.samza.metadatastore
 
org.apache.samza.metrics - package org.apache.samza.metrics
 
org.apache.samza.operators - package org.apache.samza.operators
 
org.apache.samza.operators.functions - package org.apache.samza.operators.functions
 
org.apache.samza.operators.triggers - package org.apache.samza.operators.triggers
 
org.apache.samza.operators.windows - package org.apache.samza.operators.windows
 
org.apache.samza.operators.windows.internal - package org.apache.samza.operators.windows.internal
 
org.apache.samza.runtime - package org.apache.samza.runtime
 
org.apache.samza.scheduler - package org.apache.samza.scheduler
 
org.apache.samza.serializers - package org.apache.samza.serializers
 
org.apache.samza.sql - package org.apache.samza.sql
 
org.apache.samza.sql.udfs - package org.apache.samza.sql.udfs
 
org.apache.samza.storage - package org.apache.samza.storage
 
org.apache.samza.storage.kv - package org.apache.samza.storage.kv
 
org.apache.samza.system - package org.apache.samza.system
 
org.apache.samza.system.chooser - package org.apache.samza.system.chooser
 
org.apache.samza.system.descriptors - package org.apache.samza.system.descriptors
 
org.apache.samza.table - package org.apache.samza.table
 
org.apache.samza.table.descriptors - package org.apache.samza.table.descriptors
 
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.
OutputDescriptor<StreamMessageType,SubClass extends OutputDescriptor<StreamMessageType,SubClass>> - Class in org.apache.samza.system.descriptors
An OutputDescriptor can be used for specifying Samza and system-specific properties of output streams.
OutputDescriptor(String, Serde, SystemDescriptor) - Constructor for class org.apache.samza.system.descriptors.OutputDescriptor
Constructs an OutputDescriptor instance.
OutputDescriptorProvider - Interface in org.apache.samza.system.descriptors
Interface for simple SystemDescriptors that return OutputDescriptors parameterized by the type of the provided stream level serde.
OutputStream<M> - Interface in org.apache.samza.operators
An output stream to send messages to.

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
 
partitionBy(MapFunction<? super M, ? extends K>, MapFunction<? super M, ? extends V>, KVSerde<K, V>, String) - Method in interface org.apache.samza.operators.MessageStream
Re-partitions this MessageStream using keys from the keyExtractor by creating a new intermediate stream on the default system provided via ApplicationDescriptor.withDefaultSystem(org.apache.samza.system.descriptors.SystemDescriptor<?>).
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, KeyValueStore) - Method in interface org.apache.samza.storage.SideInputsProcessor
Process the incoming side input message for the store.
process(IncomingMessageEnvelope, MessageCollector, TaskCoordinator) - Method in interface org.apache.samza.task.StreamTask
Called once for each message that this StreamTask receives.
processAsync(IncomingMessageEnvelope, MessageCollector, TaskCoordinator, TaskCallback) - Method in interface org.apache.samza.task.AsyncStreamTask
Called once for each message that this AsyncStreamTask receives.
ProcessorContext - Interface in org.apache.samza.runtime
The context for a StreamProcessor.
ProcessorIdGenerator - Interface in org.apache.samza.runtime
 
ProcessorLifecycleListener - Interface in org.apache.samza.runtime
This interface defines methods that are invoked in different stages of StreamProcessor's lifecycle in local process (i.e.
ProcessorLifecycleListenerFactory - Interface in org.apache.samza.runtime
This interface class defines the factory method to create an instance of ProcessorLifecycleListener.
processWatermark(long) - Method in interface org.apache.samza.operators.functions.WatermarkFunction
Processes the input watermark coming from upstream operators.
put(String, String) - Method in class org.apache.samza.config.Config
 
put(byte[], byte[]) - Method in interface org.apache.samza.metadatastore.MetadataStore
Updates the mapping of the specified key-value pair.
put(K, V) - Method in interface org.apache.samza.storage.kv.KeyValueStore
Updates the mapping of the specified key-value pair; Associates the specified key with the specified value.
put(K, V) - Method in interface org.apache.samza.table.ReadWriteTable
Updates the mapping of the specified key-value pair; Associates the specified key with the specified value.
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(List<Entry<K, V>>) - Method in interface org.apache.samza.storage.kv.KeyValueStore
Updates the mappings of the specified key-value entries.
putAll(List<Entry<K, V>>) - Method in interface org.apache.samza.table.ReadWriteTable
Updates the mappings of the specified key-value entries.
putAll(SystemStreamPartition, List<IncomingMessageEnvelope>) - Method in class org.apache.samza.util.BlockingEnvelopeMap
Place a collection of IncomingMessageEnvelope on the queue for the specified SystemStreamPartition.
putAllAsync(List<Entry<K, V>>) - Method in interface org.apache.samza.table.ReadWriteTable
Asynchronously updates the mappings of the specified key-value entries.
putAsync(K, V) - Method in interface org.apache.samza.table.ReadWriteTable
Asynchronously updates the mapping of the specified key-value pair; Associates the specified key with the specified value.

R

range(K, K) - Method in interface org.apache.samza.storage.kv.KeyValueStore
Returns an iterator for a sorted range of entries specified by [from, to).
RateLimiter - Interface in org.apache.samza.util
A rate limiter interface used by Samza components to limit throughput of operations against a resource.
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
 
ReadableTable<K,V> - Interface in org.apache.samza.table
A table that supports get by one or more keys
readLastCheckpoint(TaskName) - Method in interface org.apache.samza.checkpoint.CheckpointManager
Returns the last recorded checkpoint for a specified taskName.
ReadWriteTable<K,V> - Interface in org.apache.samza.table
A table that supports get, put and delete by one or more keys
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
 
repeat(Trigger<M>) - Static method in class org.apache.samza.operators.triggers.Triggers
Repeats the provided trigger forever.
RepeatingTrigger<M> - Class in org.apache.samza.operators.triggers
A Trigger that repeats its underlying trigger forever.
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
 
run() - Method in interface org.apache.samza.runtime.ApplicationRunner
Deploy and run the Samza jobs to execute SamzaApplication.
Running - Static variable in class org.apache.samza.job.ApplicationStatus
 

S

SamzaApplication<S extends ApplicationDescriptor> - Interface in org.apache.samza.application
A SamzaApplication describes the inputs, outputs, state, configuration and the logic for processing data from one or more streaming sources.
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
 
SamzaSqlRelRecord - Class in org.apache.samza.sql
Samza sql relational record.
SamzaSqlRelRecord(List<String>, List<Object>) - Constructor for class org.apache.samza.sql.SamzaSqlRelRecord
Creates a SamzaSqlRelRecord from the list of relational fields and values.
sanitize() - Method in class org.apache.samza.config.Config
 
sanitize() - Method in class org.apache.samza.config.MapConfig
 
ScalarUdf<T> - Interface in org.apache.samza.sql.udfs
The base class for the Scalar UDFs.
schedule(Scheduler<K>) - Method in interface org.apache.samza.operators.functions.ScheduledFunction
Allows scheduling the initial callback(s) and saving the scheduler for later use for recurring callbacks.
schedule(K, long) - Method in interface org.apache.samza.operators.Scheduler
Schedule a callback for the key to be invoked at timestamp.
scheduleCallback(K, long, ScheduledCallback<K>) - Method in interface org.apache.samza.scheduler.CallbackScheduler
Schedule the callback for the provided key to be invoked at epoch-time timestamp.
ScheduledCallback<K> - Interface in org.apache.samza.scheduler
The callback that is invoked when its corresponding schedule time registered via CallbackScheduler is reached.
ScheduledFunction<K,OM> - Interface in org.apache.samza.operators.functions
Allows scheduling a callback for a specific epoch-time.
Scheduler<K> - Interface in org.apache.samza.operators
Allows scheduling ScheduledFunction callbacks to be invoked later.
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
Allows sending messages in this MessageStream to an OutputStream.
sendTo(Table<KV<K, V>>) - Method in interface org.apache.samza.operators.MessageStream
Sends messages in this MessageStream to a Table.
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
Specify how a Window should process its previously emitted WindowPanes.
setCommandPath(String) - Method in class org.apache.samza.job.CommandBuilder
 
setConfig(Config) - Method in class org.apache.samza.job.CommandBuilder
 
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.context.TaskContext
Sets the starting offset for the given SystemStreamPartition.
setTimestamp(long) - Method in class org.apache.samza.system.IncomingMessageEnvelope
 
setUrl(URL) - Method in class org.apache.samza.job.CommandBuilder
 
setVersion(int) - Method in class org.apache.samza.system.ControlMessage
 
shouldBootstrap() - Method in class org.apache.samza.system.descriptors.InputDescriptor
If set, this stream will be processed as a bootstrap stream.
shouldDeleteCommittedMessages() - Method in class org.apache.samza.system.descriptors.InputDescriptor
If set, and supported by the system implementation, messages older than the latest checkpointed offset for this stream may be deleted after the commit.
shouldResetOffset() - Method in class org.apache.samza.system.descriptors.InputDescriptor
If set, when a Samza container starts up, it ignores any checkpointed offset for this particular input stream.
shutdown(TaskCoordinator.RequestScope) - Method in interface org.apache.samza.task.TaskCoordinator
Requests that the container should be shut down.
SideInputsProcessor - Interface in org.apache.samza.storage
The processing logic for store side inputs.
SideInputsProcessorFactory - Interface in org.apache.samza.storage
A factory to build SideInputsProcessors.
SimpleInputDescriptorProvider - Interface in org.apache.samza.system.descriptors
Interface for simple SystemDescriptors that return InputDescriptors parameterized by the type of the provided stream level serde.
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
Allows sending messages in this MessageStream to an output system using the provided SinkFunction.
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
snapshot(K, K) - Method in interface org.apache.samza.storage.kv.KeyValueStore
Returns a snapshot of this store for a sorted range of entries specified by [from, to).
start() - Method in interface org.apache.samza.checkpoint.CheckpointManager
Perform startup operations.
start() - Method in interface org.apache.samza.context.ApplicationContainerContext
Starts this ApplicationContainerContext before any tasks in the container are initialized and before processing begins.
start() - Method in interface org.apache.samza.context.ApplicationTaskContext
Starts this ApplicationTaskContext after its task is initialized but before any messages are processed.
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.SystemAdmin
 
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() - Method in interface org.apache.samza.runtime.ApplicationRunner
Get the collective status of the Samza jobs represented by SamzaApplication.
stop() - Method in interface org.apache.samza.checkpoint.CheckpointManager
Perform teardown operations for the Manager.
stop() - Method in interface org.apache.samza.context.ApplicationContainerContext
Stops this ApplicationContainerContext after processing ends and after all tasks in the container are closed.
stop() - Method in interface org.apache.samza.context.ApplicationTaskContext
Stops this ApplicationTaskContext after processing ends but before its task is closed.
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.SystemAdmin
 
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
A StreamApplication describes the inputs, outputs, state, configuration and the processing logic for the application in Samza's High Level API.
StreamApplicationDescriptor - Interface in org.apache.samza.application.descriptors
A StreamApplicationDescriptor contains the description of inputs, outputs, state, configuration and the processing logic for a Samza High Level API StreamApplication.
StreamDescriptor<StreamMessageType,SubClass extends StreamDescriptor<StreamMessageType,SubClass>> - Class in org.apache.samza.system.descriptors
A StreamDescriptor can be used for specifying Samza and system-specific properties of input/output streams.
StreamExpander<OM> - Interface in org.apache.samza.system.descriptors
Expands the provided InputDescriptor to a sub-DAG of one or more operators on the StreamApplicationDescriptor, and returns a new MessageStream with the combined results.
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
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, Map<String, String>) - Constructor for class org.apache.samza.system.StreamSpec
 
StreamSpec(String, String, String, int, Map<String, String>) - Constructor for class org.apache.samza.system.StreamSpec
 
StreamTableJoinFunction<K,M,R,JM> - Interface in org.apache.samza.operators.functions
Joins incoming messages with records from a table by the join key.
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
Build StreamTask instances.
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
 
SupplierFunction<T> - Interface in org.apache.samza.operators.functions
A supplier to return a new value at each invocation
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.
SystemDescriptor<SubClass extends SystemDescriptor<SubClass>> - Class in org.apache.samza.system.descriptors
A SystemDescriptor can be used for specifying Samza and system-specific properties of an input/output system.
SystemDescriptor(String, String, InputTransformer, StreamExpander) - Constructor for class org.apache.samza.system.descriptors.SystemDescriptor
Constructs a SystemDescriptor instance.
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.
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
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
 
SystemStreamPartitionMatcher - Interface in org.apache.samza.system
 
SystemStreamPartitionMetadata(String, String, String) - Constructor for class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
 

T

Table<R> - Interface in org.apache.samza.table
A Table is an abstraction for data sources that support random access by key.
TableDescriptor<K,V,D extends TableDescriptor<K,V,D>> - Interface in org.apache.samza.table.descriptors
A TableDescriptor can be used for specifying Samza and implementation-specific properties of a Table.
TableProvider - Interface in org.apache.samza.table.descriptors
A table provider provides the implementation for a table.
TableProviderFactory - Interface in org.apache.samza.table.descriptors
Factory of a table provider object
TableSpec - Class in org.apache.samza.table
TableSpec is a blueprint for creating, validating, or simply describing a table in the runtime environment.
TableSpec() - Constructor for class org.apache.samza.table.TableSpec
Default constructor
TableSpec(String, KVSerde, String, Map<String, String>) - Constructor for class org.apache.samza.table.TableSpec
Constructs a TableSpec
TableSpec(String, KVSerde, String, Map<String, String>, List<String>, SideInputsProcessor) - Constructor for class org.apache.samza.table.TableSpec
Constructs a TableSpec
TaskApplication - Interface in org.apache.samza.application
A TaskApplication describes the inputs, outputs, state, configuration and the processing logic for the application in Samza's Low Level API.
TaskApplicationDescriptor - Interface in org.apache.samza.application.descriptors
A TaskApplicationDescriptor contains the description of inputs, outputs, state, configuration and the processing logic for a Samza Low Level API TaskApplication.
TaskCallback - Interface in org.apache.samza.task
A TaskCallback is fired by a AsyncStreamTask to notify when an asynchronous process has completed.
TaskContext - Interface in org.apache.samza.context
The framework-provided context for the current task.
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 org.apache.samza.checkpoint.CheckpointManager 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).
TaskFactory<T> - Interface in org.apache.samza.task
The base interface for all task factories (i.e.
TaskModel - Class in org.apache.samza.job.model
This contains metadata about a Samza task, such as the stream partitions that it is consuming.
TaskModel(TaskName, Set<SystemStreamPartition>, Partition) - Constructor for class org.apache.samza.job.model.TaskModel
 
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
 
TimeBasedTrigger<M> - Interface in org.apache.samza.operators.triggers
A Trigger whose firing logic is determined by a time duration.
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, long, int, Clock) - Constructor for class org.apache.samza.metrics.Timer
Construct a Timer with given window size and collision buffer
Timer(String, Reservoir) - Constructor for class org.apache.samza.metrics.Timer
Construct a Timer with given Reservoir
timeSinceFirstMessage(Duration) - Static method in class org.apache.samza.operators.triggers.Triggers
Creates a trigger that fires after the specified duration has passed since the first message in the pane.
TimeSinceFirstMessageTrigger<M> - Class in org.apache.samza.operators.triggers
 
timeSinceLastMessage(Duration) - Static method in class org.apache.samza.operators.triggers.Triggers
Creates a trigger that fires when there is no new message for the specified duration in the pane.
TimeSinceLastMessageTrigger<M> - Class in org.apache.samza.operators.triggers
 
TimestampedValue<V> - Class in org.apache.samza.util
An immutable pair of a value, and its corresponding timestamp.
TimestampedValue(V, long) - Constructor for class org.apache.samza.util.TimestampedValue
 
TimeTrigger<M> - Class in org.apache.samza.operators.triggers
 
TimeTrigger(Duration) - Constructor for class org.apache.samza.operators.triggers.TimeTrigger
 
toBytes(ByteBuffer) - Method in class org.apache.samza.serializers.ByteBufferSerde
 
toBytes(byte[]) - Method in class org.apache.samza.serializers.ByteSerde
 
toBytes(Double) - Method in class org.apache.samza.serializers.DoubleSerde
 
toBytes(Integer) - Method in class org.apache.samza.serializers.IntegerSerde
 
toBytes(T) - Method in class org.apache.samza.serializers.JsonSerdeV2
 
toBytes(KV<K, V>) - Method in class org.apache.samza.serializers.KVSerde
 
toBytes(Long) - Method in class org.apache.samza.serializers.LongSerde
 
toBytes(T) - Method in class org.apache.samza.serializers.NoOpSerde
 
toBytes(T) - Method in class org.apache.samza.serializers.SerializableSerde
 
toBytes(T) - Method in interface org.apache.samza.serializers.Serializer
Serializes given object to an array of bytes.
toBytes(String) - Method in class org.apache.samza.serializers.StringSerde
 
toBytes(UUID) - Method in class org.apache.samza.serializers.UUIDSerde
 
toConfig() - Method in class org.apache.samza.system.descriptors.InputDescriptor
 
toConfig() - Method in class org.apache.samza.system.descriptors.StreamDescriptor
 
toConfig() - Method in class org.apache.samza.system.descriptors.SystemDescriptor
 
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 class org.apache.samza.job.ApplicationStatus
 
toString() - Method in class org.apache.samza.job.model.ContainerModel
 
toString() - Method in class org.apache.samza.job.model.TaskModel
 
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.operators.windows.WindowKey
 
toString() - Method in class org.apache.samza.Partition
 
toString() - Method in class org.apache.samza.runtime.LocationId
 
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.StreamSpec
 
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
 
toSystemStream() - Method in class org.apache.samza.system.StreamSpec
 
TransformingInputDescriptorProvider<InputTransformerType> - Interface in org.apache.samza.system.descriptors
Interface for advanced SystemDescriptors that constrain the type of returned InputDescriptors to their own InputTransformer function result types.
Trigger<M> - Interface in org.apache.samza.operators.triggers
Marker interface for all triggers.
Triggers - Class in org.apache.samza.operators.triggers
API for creating Trigger instances to be used with a Window.
tumblingWindow(Duration, SupplierFunction<? extends WV>, FoldLeftFunction<? super M, WV>, Serde<WV>) - Static method in class org.apache.samza.operators.windows.Windows
Creates a Window that windows values into fixed-size processing time based windows and aggregates them applying the provided function.
tumblingWindow(Duration, Serde<M>) - Static method in class org.apache.samza.operators.windows.Windows
Creates a Window that groups incoming messages into fixed-size, non-overlapping processing time based windows.

U

unlisten(ReadableMetricsRegistryListener) - Method in interface org.apache.samza.metrics.ReadableMetricsRegistry
 
UnsuccessfulFinish - Static variable in class org.apache.samza.job.ApplicationStatus
 
unsuccessfulFinish(Throwable) - Static method in class org.apache.samza.job.ApplicationStatus
 
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
 
UUIDSerde - Class in org.apache.samza.serializers
A serializer for UUID
UUIDSerde() - Constructor for class org.apache.samza.serializers.UUIDSerde
 
UUIDSerdeFactory - Class in org.apache.samza.serializers
 
UUIDSerdeFactory() - Constructor for class org.apache.samza.serializers.UUIDSerdeFactory
 

V

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 class org.apache.samza.metrics.ListGauge
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
waitForFinish() - Method in interface org.apache.samza.runtime.ApplicationRunner
Waits until the application finishes.
waitForFinish(Duration) - Method in interface org.apache.samza.runtime.ApplicationRunner
Waits for timeout duration for the application to finish.
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
WatermarkFunction<T> - Interface in org.apache.samza.operators.functions
Allows handling of watermarks.
WatermarkMessage - Class in org.apache.samza.system
The WatermarkMessage is a control message that is sent out to next stage with a watermark timestamp and the task that produces the watermark.
WatermarkMessage(long) - Constructor for class org.apache.samza.system.WatermarkMessage
 
WatermarkMessage(long, String) - Constructor for class org.apache.samza.system.WatermarkMessage
 
window(Window<M, K, WV>, String) - Method in interface org.apache.samza.operators.MessageStream
Groups the messages in this MessageStream according to the provided Window semantics (e.g.
Window<M,K,WV> - Interface in org.apache.samza.operators.windows
Groups incoming messages in the MessageStream into finite windows for processing.
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).
WindowInternal<M,WK,WV> - Class in org.apache.samza.operators.windows.internal
Internal representation of a Window.
WindowInternal(Trigger<M>, SupplierFunction<WV>, FoldLeftFunction<M, WV>, MapFunction<M, WK>, MapFunction<M, Long>, WindowType, Serde<WK>, Serde<WV>, Serde<M>) - Constructor for class org.apache.samza.operators.windows.internal.WindowInternal
 
WindowKey<K> - Class in org.apache.samza.operators.windows
Key for a WindowPane emitted from a Window.
WindowKey(K, String) - Constructor for class org.apache.samza.operators.windows.WindowKey
 
WindowPane<K,V> - Class in org.apache.samza.operators.windows
Specifies the result emitted from a Window.
WindowPane(WindowKey<K>, V, AccumulationMode, FiringType) - Constructor for class org.apache.samza.operators.windows.WindowPane
 
Windows - Class in org.apache.samza.operators.windows
APIs for creating different types of Windows.
WindowType - Enum in org.apache.samza.operators.windows.internal
 
withApplicationContainerContextFactory(ApplicationContainerContextFactory<?>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
Sets the ApplicationContainerContextFactory for this application.
withApplicationTaskContextFactory(ApplicationTaskContextFactory<?>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
Sets the ApplicationTaskContextFactory for this application.
withConfig(String, String) - Method in interface org.apache.samza.table.descriptors.TableDescriptor
Add a configuration entry for the table
withDefaultStreamConfigs(Map<String, String>) - Method in class org.apache.samza.system.descriptors.SystemDescriptor
Default properties for any stream obtained using this system descriptor.
withDefaultStreamOffsetDefault(SystemStreamMetadata.OffsetType) - Method in class org.apache.samza.system.descriptors.SystemDescriptor
If a container starts up without a checkpoint, this property determines where in the input stream we should start consuming.
withDefaultSystem(SystemDescriptor<?>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
Sets the SystemDescriptor for the default system for the application.
withInputStream(InputDescriptor) - Method in interface org.apache.samza.application.descriptors.TaskApplicationDescriptor
Adds the input stream to the application.
withMetricsReporterFactories(Map<String, MetricsReporterFactory>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
Sets the MetricsReporterFactorys for creating the MetricsReporters to use for the application.
withOffsetDefault(SystemStreamMetadata.OffsetType) - Method in class org.apache.samza.system.descriptors.InputDescriptor
If a container starts up without a checkpoint, this property determines where in the input stream we should start consuming.
withOutputStream(OutputDescriptor) - Method in interface org.apache.samza.application.descriptors.TaskApplicationDescriptor
Adds the output stream to the application.
withPhysicalName(String) - Method in class org.apache.samza.system.descriptors.GenericInputDescriptor
 
withPhysicalName(String) - Method in class org.apache.samza.system.descriptors.GenericOutputDescriptor
 
withPhysicalName(String) - Method in class org.apache.samza.system.descriptors.StreamDescriptor
The physical name of the stream on the system on which this stream will be accessed.
withPriority(int) - Method in class org.apache.samza.system.descriptors.InputDescriptor
If one or more streams have a priority set (any positive integer), they will be processed with higher priority than the other streams.
withProcessorLifecycleListenerFactory(ProcessorLifecycleListenerFactory) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
Sets the ProcessorLifecycleListenerFactory for this application.
withStreamConfigs(Map<String, String>) - Method in class org.apache.samza.system.descriptors.StreamDescriptor
Additional system-specific properties for this stream.
withSystemConfigs(Map<String, String>) - Method in class org.apache.samza.system.descriptors.SystemDescriptor
Additional system-specific properties for this system.
withTable(TableDescriptor) - Method in interface org.apache.samza.application.descriptors.TaskApplicationDescriptor
Adds the TableDescriptor used in the application
withTaskFactory(TaskFactory) - Method in interface org.apache.samza.application.descriptors.TaskApplicationDescriptor
Sets the StreamTaskFactory or AsyncStreamTaskFactory for the StreamTask or AsyncStreamTask implementation that contains the processing logic for the TaskApplication.
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 J K L M N O P R S T U V W 
Skip navigation links