- AccumulationMode - Enum in org.apache.samza.operators.windows
-
- 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.
- addField(String, SqlFieldSchema) - Method in class org.apache.samza.sql.schema.SqlSchemaBuilder
-
- addOperation(Operation<K, V>) - Method in interface org.apache.samza.table.batching.Batch
-
Add an operation to the batch.
- addStoreConfig(String, String, Map<String, String>) - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
Helper method to add a store level config item to table configuration
- addTableConfig(String, String, Map<String, String>) - Method in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
Helper method to add a config item to table configuration
- addTablePartConfig(String, TablePart, Config, Map<String, String>) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Helper method to add table part config items to table configuration
- afterCheckpoint(Map<SystemStreamPartition, String>) - Method in interface org.apache.samza.checkpoint.CheckpointListener
-
Called after writing the checkpoint for each Task in the Container processing SSPs on this system.
- 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 class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- 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
-
- ApplicationContainerContextFactory<T extends ApplicationContainerContext> - Interface in org.apache.samza.context
-
- ApplicationDescriptor<S extends ApplicationDescriptor> - Interface in org.apache.samza.application.descriptors
-
- ApplicationRunner - Interface in org.apache.samza.runtime
-
- ApplicationRunners - Class in org.apache.samza.runtime
-
- 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
-
- ApplicationTaskContextFactory<T extends ApplicationTaskContext> - Interface in org.apache.samza.context
-
- apply(M) - Method in interface org.apache.samza.operators.functions.AsyncFlatMapFunction
-
Transforms the provided message into a collection of 0 or more messages.
- 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
-
- apply(M, R) - Method in interface org.apache.samza.operators.functions.StreamTableJoinFunction
-
Joins the provided messages and table record, returns the joined message.
- apply(IN, StartpointVisitor<IN, OUT>) - Method in class org.apache.samza.startpoint.Startpoint
-
- apply(IN, StartpointVisitor<IN, OUT>) - Method in class org.apache.samza.startpoint.StartpointOldest
-
- apply(IN, StartpointVisitor<IN, OUT>) - Method in class org.apache.samza.startpoint.StartpointSpecific
-
- apply(IN, StartpointVisitor<IN, OUT>) - Method in class org.apache.samza.startpoint.StartpointTimestamp
-
- apply(IN, StartpointVisitor<IN, OUT>) - Method in class org.apache.samza.startpoint.StartpointUpcoming
-
- 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
-
- ASYNC_CALLBACK_POOL_SIZE - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- AsyncFlatMapFunction<M,OM> - Interface in org.apache.samza.operators.functions
-
- AsyncReadWriteTable<K,V> - Interface in org.apache.samza.table
-
A table that supports asynchronous get, put and delete by one or more keys
- 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
-
- CACHE_SIZE - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- CACHE_TABLE_ID - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- CachingTableDescriptor<K,V> - Class in org.apache.samza.table.descriptors
-
Table descriptor for a caching table.
- CachingTableDescriptor(String, TableDescriptor<K, V, ?>) - Constructor for class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Constructs a table descriptor instance with internal cache
- CachingTableDescriptor(String, TableDescriptor<K, V, ?>, TableDescriptor<K, V, ?>) - Constructor for class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Constructs a table descriptor instance and specify a cache (as Table descriptor)
to be used for caching.
- CallbackScheduler - Interface in org.apache.samza.scheduler
-
Provides a way for applications to register some logic to be executed at a future time.
- changelogReplicationFactor - Variable in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- ChangelogSSPIterator - Class in org.apache.samza.system
-
- ChangelogSSPIterator(SystemConsumer, SystemStreamPartition, String, SystemAdmin, boolean) - Constructor for class org.apache.samza.system.ChangelogSSPIterator
-
- ChangelogSSPIterator.Mode - Enum in org.apache.samza.system
-
- changelogStream - Variable in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- 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.
- checkpoint(CheckpointId) - Method in interface org.apache.samza.storage.kv.KeyValueStore
-
Create a persistent checkpoint / snapshot of the current store state and return it's path.
- checkpoint(CheckpointId) - Method in interface org.apache.samza.storage.StorageEngine
-
Checkpoint store snapshots.
- CheckpointedChangelogOffset - Class in org.apache.samza.checkpoint
-
Checkpointed changelog offset has the format: [checkpointId, offset], separated by a colon.
- CheckpointedChangelogOffset(CheckpointId, String) - Constructor for class org.apache.samza.checkpoint.CheckpointedChangelogOffset
-
- CheckpointId - Class in org.apache.samza.checkpoint
-
Checkpoint ID has the format: [currentTimeMillis, last 6 digits of nanotime], separated by a dash.
- CheckpointId(long, long) - Constructor for class org.apache.samza.checkpoint.CheckpointId
-
- CheckpointListener - Interface in org.apache.samza.checkpoint
-
SystemConsumers that want to be notified about checkpoints for their SSPs and potentially modify them may
implement this interface.
- 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 class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- 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
-
- 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.AsyncReadWriteTable
-
Close the table and release any resources acquired
- close() - Method in interface org.apache.samza.table.batching.Batch
-
Close the bach so that it will not accept more operations.
- close() - Method in interface org.apache.samza.table.TableProvider
-
Shutdown the underlying table
- 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.table.batching.Batch
-
Change the batch status to be complete.
- complete() - Method in interface org.apache.samza.task.TaskCallback
-
Invoke when the asynchronous process completed with success.
- completeExceptionally(Throwable) - Method in interface org.apache.samza.table.batching.Batch
-
Change the batch status to be complete with exception.
- 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
-
- config - Variable in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
- CONFIG_LOADER_PROPERTIES_PREFIX - Static variable in interface org.apache.samza.config.ConfigLoaderFactory
-
job.config.loader.properties prefix wraps properties needed for
ConfigLoader
to loader config.
- ConfigException - Exception in org.apache.samza.config
-
- ConfigException(Throwable) - Constructor for exception org.apache.samza.config.ConfigException
-
- ConfigException(String) - Constructor for exception org.apache.samza.config.ConfigException
-
- ConfigException(String, Throwable) - Constructor for exception org.apache.samza.config.ConfigException
-
- ConfigFactory - Interface in org.apache.samza.config
-
- ConfigLoader - Interface in org.apache.samza.config
-
The primary means of fetching full job
Config
on
LocalApplicationRunner and ClusterBasedJobCoordinator during start up.
- ConfigLoaderFactory - Interface in org.apache.samza.config
-
The factory for an
ConfigLoader
instance to load full job 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
-
- ContainerPlacementMessage - Class in org.apache.samza.container.placement
-
Encapsulates the request or response payload information between the ContainerPlacementService and external
controllers issuing placement actions
- ContainerPlacementMessage(UUID, String, String, String, Duration, ContainerPlacementMessage.StatusCode, long) - Constructor for class org.apache.samza.container.placement.ContainerPlacementMessage
-
- ContainerPlacementMessage(UUID, String, String, String, ContainerPlacementMessage.StatusCode, long) - Constructor for class org.apache.samza.container.placement.ContainerPlacementMessage
-
- ContainerPlacementMessage.StatusCode - Enum in org.apache.samza.container.placement
-
- ContainerPlacementRequestMessage - Class in org.apache.samza.container.placement
-
Encapsulates the request sent from the external controller to the JobCoordinator to take a container placement action
- ContainerPlacementRequestMessage(UUID, String, String, String, Duration, long) - Constructor for class org.apache.samza.container.placement.ContainerPlacementRequestMessage
-
- ContainerPlacementRequestMessage(UUID, String, String, String, long) - Constructor for class org.apache.samza.container.placement.ContainerPlacementRequestMessage
-
- ContainerPlacementResponseMessage - Class in org.apache.samza.container.placement
-
Encapsulates the value for the response sent from the JobCoordinator for a container placement action
- ContainerPlacementResponseMessage(UUID, String, String, String, Duration, ContainerPlacementMessage.StatusCode, String, long) - Constructor for class org.apache.samza.container.placement.ContainerPlacementResponseMessage
-
- ContainerPlacementResponseMessage(UUID, String, String, String, ContainerPlacementMessage.StatusCode, String, long) - Constructor for class org.apache.samza.container.placement.ContainerPlacementResponseMessage
-
- containsField(String) - Method in class org.apache.samza.sql.SamzaSqlRelRecord
-
- containsField(String) - Method in class org.apache.samza.sql.schema.SqlSchema
-
- 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() - Static method in class org.apache.samza.checkpoint.CheckpointId
-
- create(ExternalContext, JobContext, ContainerContext) - Method in interface org.apache.samza.context.ApplicationContainerContextFactory
-
- create(JobContext, ContainerContext) - Method in interface org.apache.samza.context.ApplicationContainerContextFactory
-
Deprecated.
- create(ExternalContext, JobContext, ContainerContext, TaskContext, ApplicationContainerContext) - Method in interface org.apache.samza.context.ApplicationTaskContextFactory
-
- create(JobContext, ContainerContext, TaskContext, ApplicationContainerContext) - Method in interface org.apache.samza.context.ApplicationTaskContextFactory
-
Deprecated.
- createArraySchema(SqlFieldSchema, boolean, boolean) - Static method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- 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
-
- createInstance() - Method in interface org.apache.samza.task.TaskFactory
-
Create instance of task
- createMapSchema(SqlFieldSchema, boolean, boolean) - Static method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- createPrimitiveSchema(SamzaSqlFieldType, boolean, boolean) - Static method in class org.apache.samza.sql.schema.SqlFieldSchema
-
Create a primitive field schema.
- createResources() - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
Creates checkpoint stream.
- createRowFieldSchema(SqlSchema, boolean, boolean) - Static method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- 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
-
- dec() - Method in class org.apache.samza.metrics.Counter
-
- dec(long) - Method in class org.apache.samza.metrics.Counter
-
- DEFAULT_RATE_LIMITER_CLASS_NAME - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- delete(String) - Method in class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- delete(String) - 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, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Deletes the mapping for the specified key
from this table (if such mapping exists).
- delete(K) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Delete the record
with specified key
from the remote store.
- 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>, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Deletes the mappings for the specified keys
from this table.
- deleteAll(Collection<K>) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Delete all records
with the specified keys
from the remote store
The default implementation calls deleteAllAsync and blocks on the completion afterwards.
- deleteAllAsync(List<K>, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously deletes the mappings for the specified keys
from this table.
- deleteAllAsync(Collection<K>) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously delete all records
with the specified keys
from the remote store.
- deleteAllAsync(Collection<K>, Object...) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously delete all records
with the specified keys
and additional arguments from
the remote store.
- deleteAsync(K, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously deletes the mapping for the specified key
from this table (if such mapping exists).
- deleteAsync(K) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously delete the record
with specified key
from the remote store
- deleteAsync(K, Object...) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously delete the record
with specified key
and additional arguments from the remote store
- 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
- deploymentId - Variable in class org.apache.samza.container.placement.ContainerPlacementMessage
-
Unique identifier for a deployment so messages can be invalidated across a job restarts
for ex yarn bases cluster manager can be set to app attempt id
- describe(S) - Method in interface org.apache.samza.application.SamzaApplication
-
Describes the inputs, outputs, state, configuration and processing logic using the provided appDescriptor
.
- deserialize(String, String) - Static method in class org.apache.samza.table.utils.SerdeUtils
-
Helper method to deserialize Java objects from Base64 strings
- 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.
- destinationHost - Variable in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- 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.
- Gauge<T> - Class in org.apache.samza.metrics
-
A Gauge is a
Metric
that wraps some instance of T in a thread-safe
reference and allows it to be set or retrieved.
- Gauge(String, T) - Constructor for class org.apache.samza.metrics.Gauge
-
- gauge(Gauge<T>) - Method in class org.apache.samza.metrics.MetricsVisitor
-
- generateProcessorId(Config) - Method in interface org.apache.samza.runtime.ProcessorIdGenerator
-
Generates a String representation to identify a single instance of StreamProcessor.
- GenericInputDescriptor<StreamMessageType> - Class in org.apache.samza.system.descriptors
-
- GenericOutputDescriptor<StreamMessageType> - Class in org.apache.samza.system.descriptors
-
- 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
-
- get(String, String) - Method in class org.apache.samza.config.Config
-
- get(Object) - Method in class org.apache.samza.config.MapConfig
-
- get(String) - Method in class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- get(String) - 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, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Gets the value associated with the specified key
.
- get(K) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Fetch single table record for a 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>, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Gets the values with which the specified keys
are associated.
- getAll(Collection<K>) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Fetch the table records
for specified keys
.
- getAllAsync(List<K>, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously gets the values with which the specified keys
are associated.
- getAllAsync(Collection<K>) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Asynchronously fetch the table records
for specified keys
.
- getAllAsync(Collection<K>, Object...) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Asynchronously fetch the table records
for specified keys
and additional arguments.
- getAllSystemStreams() - Method in interface org.apache.samza.system.SystemAdmin
-
Fetch the set of all available streams
- 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
-
- getApplicationTaskContext() - Method in interface org.apache.samza.context.Context
-
Gets the application-defined task context for the current task.
- getArgs() - Method in interface org.apache.samza.table.batching.Operation
-
- getArrivalTime() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
Getter for arrival time
- getAsync(K, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously gets the value associated with the specified key
.
- getAsync(K) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Asynchronously fetch single table record for a specified key
.
- getAsync(K, Object...) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Asynchronously fetch single table record for a specified key
with additional arguments.
- getAverage() - Method in class org.apache.samza.metrics.Snapshot
-
Get the average of the values in the collection
- getBackoffType() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getBatch() - Method in class org.apache.samza.table.batching.BatchProvider
-
- 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
-
- getCheckpointId() - Method in class org.apache.samza.checkpoint.CheckpointedChangelogOffset
-
- 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.config.ConfigLoader
-
- 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
-
- 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
-
- 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
- getCreationTimestamp() - Method in class org.apache.samza.startpoint.Startpoint
-
The timestamp when this
Startpoint
was written to the storage layer.
- getCredits(K, V, Object...) - Method in interface org.apache.samza.table.remote.TableRateLimiter.CreditFunction
-
Get the number of credits required for the key
and value
pair.
- getCredits(int, Object...) - Method in interface org.apache.samza.table.remote.TableRateLimiter.CreditFunction
-
Get the number of credits required for the opId
and associated args
.
- 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
-
- getDeploymentId() - Method in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- getDestinationHost() - Method in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- 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
-
- getElementSchema() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- getEventTime() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
Getter for event time
- getEventTimeExtractor() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getExpander() - Method in class org.apache.samza.system.descriptors.SystemDescriptor
-
- getExponentialFactor() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getExponentialMaxSleep() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getExternalContext() - Method in interface org.apache.samza.context.Context
-
- getField(String) - Method in class org.apache.samza.sql.SamzaSqlRelRecord
-
Get the value of the field corresponding to the field name.
- getFieldName() - Method in class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- getFieldNames() - Method in class org.apache.samza.sql.SamzaSqlRelRecord
-
Get the field names of all the columns in the relational message.
- getFields() - Method in class org.apache.samza.sql.schema.SqlSchema
-
- getFieldSchema() - Method in class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- getFieldType() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
Get the Type of the Samza SQL Field.
- 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
-
- getForTable(String, String, String) - Method in class org.apache.samza.config.JavaTableConfig
-
Get table config value for a key
- getForTable(String, String) - Method in class org.apache.samza.config.JavaTableConfig
-
Get table config value for a key
- 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
-
- getInitializer() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getInputDescriptor(String, Serde) - Method in interface org.apache.samza.system.descriptors.ExpandingInputDescriptorProvider
-
- 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
-
- getInputDescriptor(String, Serde) - Method in interface org.apache.samza.system.descriptors.TransformingInputDescriptorProvider
-
- 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
-
- getJitter() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Introduce randomness to the sleepTime time.
- 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
-
- getKey() - Method in interface org.apache.samza.table.batching.Operation
-
- getKeyExtractor() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getKeySerde(String) - Method in class org.apache.samza.config.JavaTableConfig
-
Get registry keys of key serde for this table
- 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
-
- getLoader(Config) - Method in interface org.apache.samza.config.ConfigLoaderFactory
-
- 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
- getMaxAttempts() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Termination after a fix number of attempts.
- getMaxBatchDelay() - Method in interface org.apache.samza.table.batching.Batch
-
- getMaxBatchDelay() - Method in class org.apache.samza.table.batching.BatchProvider
-
- getMaxBatchSize() - Method in interface org.apache.samza.table.batching.Batch
-
- getMaxBatchSize() - Method in class org.apache.samza.table.batching.BatchProvider
-
- getMaxDuration() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Termination after a fixed duration.
- 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 class org.apache.samza.metadatastore.InMemoryMetadataStoreFactory
-
- getMetadataStore(String, Config, MetricsRegistry) - Method in interface org.apache.samza.metadatastore.MetadataStoreFactory
-
- getMetricsReporter(String, String, Config) - Method in interface org.apache.samza.metrics.MetricsReporterFactory
-
- getMillis() - Method in class org.apache.samza.checkpoint.CheckpointId
-
- 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
-
- getMode() - Method in class org.apache.samza.system.ChangelogSSPIterator
-
- getMsgSerde(String) - Method in class org.apache.samza.config.JavaTableConfig
-
Get registry keys of value serde for this table
- getMsgSerde() - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- getName() - Method in class org.apache.samza.metrics.Counter
-
- getName() - Method in class org.apache.samza.metrics.Gauge
-
- getName() - Method in class org.apache.samza.metrics.Timer
-
Get the name of the timer
- getNanos() - Method in class org.apache.samza.checkpoint.CheckpointId
-
- 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.checkpoint.CheckpointedChangelogOffset
-
- getOffset() - Method in class org.apache.samza.system.IncomingMessageEnvelope
-
Offset associated with this message, provided by the system consumer that consumed the message.
- 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
-
- getOperations() - Method in interface org.apache.samza.table.batching.Batch
-
- 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
-
- getPosition() - Method in class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- getPreviousSSP(SystemStreamPartition, int, int) - Method in interface org.apache.samza.container.grouper.stream.SystemStreamPartitionMapper
-
- getProcessorId() - Method in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- getProducer(String, Config, MetricsRegistry) - Method in interface org.apache.samza.system.SystemFactory
-
- getProviderFactoryClassName() - Method in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
- getProviderFactoryClassName() - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- getProviderFactoryClassName() - Method in class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
- getProviderFactoryClassName() - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- getRandomMax() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getRandomMin() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getRecordKey(R) - Method in interface org.apache.samza.operators.functions.StreamTableJoinFunction
-
Retrieve the join key from table record
- getRequestExpiry() - Method in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- getResponseMessage() - Method in class org.apache.samza.container.placement.ContainerPlacementResponseMessage
-
- getRetryPredicate() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getRowSchema() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- 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.descriptors.LocalTableDescriptor
-
- 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.descriptors.LocalTableDescriptor
-
Get side input stream names
- getSideInputsProcessor(Config, MetricsRegistry) - Method in interface org.apache.samza.storage.SideInputsProcessorFactory
-
- 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
-
- getSleepTime() - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
- getSnapshot() - Method in interface org.apache.samza.metrics.Reservoir
-
- getSnapshot() - Method in class org.apache.samza.metrics.SlidingTimeWindowReservoir
-
- getSnapshot() - Method in class org.apache.samza.metrics.Timer
-
- getSpecificOffset() - Method in class org.apache.samza.startpoint.StartpointSpecific
-
Getter for the specific offset.
- 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
-
- getStatusCode() - Method in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- getStatusCode() - Method in class org.apache.samza.job.ApplicationStatus
-
- getStorageEngine(String, File, Serde<K>, Serde<V>, MessageCollector, MetricsRegistry, SystemStreamPartition, JobContext, ContainerContext, StorageEngineFactory.StoreMode) - 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
-
- 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
-
- getStreamPartitionMapper(Config, MetricsRegistry) - Method in interface org.apache.samza.container.grouper.stream.SystemStreamPartitionMapperFactory
-
- 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.SystemAdmin
-
Get partitions counts only.
- 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
-
- getTable(TableDescriptor<K, V, ?>) - Method in interface org.apache.samza.application.descriptors.StreamApplicationDescriptor
-
- getTable(String) - Method in interface org.apache.samza.context.TaskContext
-
- getTable() - Method in interface org.apache.samza.table.TableProvider
-
- getTableDescriptors() - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Retrieve user-defined table descriptors contained in this table
- getTableDescriptors() - Method in class org.apache.samza.table.descriptors.HybridTableDescriptor
-
Get tables contained within this table.
- getTableId() - Method in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
- getTableId() - Method in interface org.apache.samza.table.descriptors.TableDescriptor
-
Get the id of the table
- getTableIds() - Method in class org.apache.samza.config.JavaTableConfig
-
Get Id's of all tables
- getTableProvider(String) - Method in interface org.apache.samza.table.TableProviderFactory
-
Construct a table provider based on job configuration
- getTableProviderFactory(String) - Method in class org.apache.samza.config.JavaTableConfig
-
- 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.
- getTaskMode() - Method in class org.apache.samza.job.model.TaskModel
-
- getTaskModel() - Method in interface org.apache.samza.context.TaskContext
-
- 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.container.placement.ContainerPlacementMessage
-
- getTimestamp() - Method in class org.apache.samza.system.WatermarkMessage
-
- getTimestamp() - Method in class org.apache.samza.util.TimestampedValue
-
- getTimestampOffset() - Method in class org.apache.samza.startpoint.StartpointTimestamp
-
Getter for the timestamp offset.
- 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
-
- getUuid() - Method in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- 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 interface org.apache.samza.table.batching.Operation
-
- 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.Snapshot
-
Return the entire list of values
- getValueSchema() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- 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
-
Groups the input systemStreamPartitions into the logical taskNames.
- GUAVA_CACHE - Static variable in class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
- GuavaCacheTableDescriptor<K,V> - Class in org.apache.samza.table.descriptors
-
Table descriptor for Guava-based caching table.
- GuavaCacheTableDescriptor(String) - Constructor for class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
Constructs a table descriptor instance
- 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.
- IncomingMessageEnvelope(SystemStreamPartition, String, Object, Object, int, long, long) - 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 class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- 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, Context) - 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.AsyncReadWriteTable
-
Initializes the table during container initialization.
- init(Context, AsyncReadWriteTable) - Method in class org.apache.samza.table.remote.BaseTableFunction
-
- init(Context, AsyncReadWriteTable) - Method in interface org.apache.samza.table.remote.TableFunction
-
Initializes the function before any operation.
- init(Context) - Method in interface org.apache.samza.table.TableProvider
-
Initialize TableProvider with container and task context
- 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
-
- InMemoryMetadataStore - Class in org.apache.samza.metadatastore
-
- InMemoryMetadataStore() - Constructor for class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- InMemoryMetadataStoreFactory - Class in org.apache.samza.metadatastore
-
- InMemoryMetadataStoreFactory() - Constructor for class org.apache.samza.metadatastore.InMemoryMetadataStoreFactory
-
- 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
-
- 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
-
- isCheckpointStream() - Method in class org.apache.samza.system.StreamSpec
-
- isClosed() - Method in interface org.apache.samza.table.batching.Batch
-
- isCoordinatorStream() - Method in class org.apache.samza.system.StreamSpec
-
- isEmpty() - Method in class org.apache.samza.config.MapConfig
-
- isEmpty() - Method in interface org.apache.samza.table.batching.Batch
-
- 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
- isNullable() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
Get if the field type is nullable.
- isOptional() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
Get if the field type is optional.
- isPersistedToDisk() - Method in class org.apache.samza.storage.StoreProperties
-
Flag to indicate whether a store can be persisted to disk or not
- isPrimitiveField() - Method in class org.apache.samza.sql.schema.SqlFieldSchema
-
- isRetriable(Throwable) - Method in interface org.apache.samza.table.remote.TableFunction
-
Determine whether the current operation can be retried with the last thrown exception.
- iterator() - Method in interface org.apache.samza.storage.kv.KeyValueSnapshot
-
Creates a new iterator for this snapshot.
- 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
-
- 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.
- processorId - Variable in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- 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
-
- processWatermark(long) - Method in interface org.apache.samza.operators.functions.WatermarkFunction
-
Processes the input watermark coming from upstream operators.
- PROVIDER_FACTORY_CLASS_NAME - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- PROVIDER_FACTORY_CLASS_NAME - Static variable in class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
- PROVIDER_FACTORY_CLASS_NAME - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- put(String, String) - Method in class org.apache.samza.config.Config
-
- put(String, byte[]) - Method in class org.apache.samza.metadatastore.InMemoryMetadataStore
-
- put(String, 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, Object...) - 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(K, V) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Store single table record
with specified key
.
- put(SystemStreamPartition, IncomingMessageEnvelope) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- putAll(Map<? extends String, ? extends String>) - Method in class org.apache.samza.config.Config
-
- putAll(Map<String, byte[]>) - Method in interface org.apache.samza.metadatastore.MetadataStore
-
Updates the mapping with the specified map.
- 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>>, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Updates the mappings of the specified key-value entries
.
- putAll(List<Entry<K, V>>) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Store the table records
with specified keys
.
- putAll(SystemStreamPartition, List<IncomingMessageEnvelope>) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- putAllAsync(List<Entry<K, V>>, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously updates the mappings of the specified key-value entries
.
- putAllAsync(Collection<Entry<K, V>>) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously store the table records
with specified keys
.
- putAllAsync(Collection<Entry<K, V>>, Object...) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously store the table records
with specified keys
and additional arguments.
- putAsync(K, V, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously updates the mapping of the specified key-value pair;
Associates the specified key
with the specified value
.
- putAsync(K, V) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously store single table record
with specified key
.
- putAsync(K, V, Object...) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously store single table record
with specified key
and additional arguments.
- 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
).
- RATE_LIMITER - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- RateLimiter - Interface in org.apache.samza.util
-
A rate limiter interface used by Samza components to limit throughput of operations
against a resource.
- read(int, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Executes a read operation.
- READ_CREDIT_FN - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- READ_FN - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- READ_RETRY_POLICY - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- READ_TTL_MS - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- 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
-
- readAsync(int, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously executes a read operation.
- readAsync(int, Object...) - Method in interface org.apache.samza.table.remote.TableReadFunction
-
Asynchronously read data from table for specified opId
and additional arguments.
- 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 synchronous and asynchronousget, put and delete by one or more keys
- REAL_TABLE_ID - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- 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.
- RemoteTableDescriptor<K,V> - Class in org.apache.samza.table.descriptors
-
Table descriptor for remote store backed tables
- RemoteTableDescriptor(String) - Constructor for class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Constructs a table descriptor instance
- 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.
- replaceAll(BiFunction<? super String, ? super String, ? extends String>) - Method in class org.apache.samza.config.Config
-
- requestExpiry - Variable in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- Reservoir - Interface in org.apache.samza.metrics
-
A reservoir interface to store, update and display values
- resolveStartpointToOffset(SystemStreamPartition, Startpoint) - Method in interface org.apache.samza.system.SystemAdmin
-
Resolves the startpoint to a system specific offset.
- restore(ChangelogSSPIterator) - 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
-
- RL_READ_TAG - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Tag to be used for provision credits for rate limiting read operations from the remote table.
- RL_WRITE_TAG - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Tag to be used for provision credits for rate limiting write operations into the remote table.
- run() - Method in interface org.apache.samza.runtime.ApplicationRunner
-
- run(ExternalContext) - Method in interface org.apache.samza.runtime.ApplicationRunner
-
- Running - Static variable in class org.apache.samza.job.ApplicationStatus
-
- 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
-
- SamzaHistogram - Class in org.apache.samza.metrics
-
Creates a
Histogram
metric using
ExponentiallyDecayingReservoir
Keeps a
Gauge
for each percentile
- SamzaHistogram(MetricsRegistry, String, String) - Constructor for class org.apache.samza.metrics.SamzaHistogram
-
- SamzaHistogram(MetricsRegistry, String, String, List<Double>) - Constructor for class org.apache.samza.metrics.SamzaHistogram
-
- SamzaSqlFieldType - Enum in org.apache.samza.sql.schema
-
Type of the Samza SQL field
- SamzaSqlRelRecord - Class in org.apache.samza.sql
-
Samza sql relational record.
- SamzaSqlRelRecord(List<String>, List<Object>) - Constructor for class org.apache.samza.sql.SamzaSqlRelRecord
-
- SamzaSqlUdf - Annotation Type in org.apache.samza.sql.udfs
-
Java annotation to identity a Samza SQL Udf
- SamzaSqlUdfMethod - Annotation Type in org.apache.samza.sql.udfs
-
Java annotation to identity the Samza SQL Udf method and it's argument types and return types.
- sanitize() - Method in class org.apache.samza.config.Config
-
- sanitize() - Method in class org.apache.samza.config.MapConfig
-
- ScalarUdf - Interface in org.apache.samza.sql.udfs
-
The base class for the Scalar UDFs.
- 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
-
- 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
-
- sendTo(Table<KV<K, V>>, Object...) - Method in interface org.apache.samza.operators.MessageStream
-
- SENSITIVE_MASK - Static variable in class org.apache.samza.config.Config
-
- SENSITIVE_PREFIX - Static variable in class org.apache.samza.config.Config
-
- SEPARATOR - Static variable in class org.apache.samza.checkpoint.CheckpointedChangelogOffset
-
- SEPARATOR - Static variable in class org.apache.samza.checkpoint.CheckpointId
-
- 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.
- serde - Variable in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- SerdeFactory<T> - Interface in org.apache.samza.serializers
-
Build an instance of
Serde
- SerdeUtils - Class in org.apache.samza.table.utils
-
- SerdeUtils() - Constructor for class org.apache.samza.table.utils.SerdeUtils
-
- 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
-
- serialize(String, T) - Static method in class org.apache.samza.table.utils.SerdeUtils
-
Helper method to serialize Java objects as Base64 strings
- Serializer<T> - Interface in org.apache.samza.serializers
-
A standard interface for Samza compatible serializers, used for serializing objects to bytes.
- set(long) - Method in class org.apache.samza.metrics.Counter
-
- set(T) - Method in class org.apache.samza.metrics.Gauge
-
- setAccumulationMode(AccumulationMode) - Method in class org.apache.samza.operators.windows.internal.WindowInternal
-
- setAccumulationMode(AccumulationMode) - Method in interface org.apache.samza.operators.windows.Window
-
- setCommandPath(String) - Method in class org.apache.samza.job.CommandBuilder
-
- setConfig(Config) - Method in class org.apache.samza.job.CommandBuilder
-
- setEarlyTrigger(Trigger<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
.
- setFailureCause(Throwable) - Method in class org.apache.samza.util.BlockingEnvelopeMap
-
- setFieldName(String) - Method in class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- setFieldSchema(SqlFieldSchema) - Method in class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- 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
-
- setPosition(int) - Method in class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- setStartingOffset(SystemStreamPartition, String) - Method in interface org.apache.samza.context.TaskContext
-
- setTimerMetric(Timer) - Method in class org.apache.samza.table.remote.TableRateLimiter
-
Set up waitTimeMetric metric for latency reporting due to throttling.
- 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.
- sideInputs - Variable in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- SideInputsProcessor - Interface in org.apache.samza.storage
-
The processing logic for store side inputs.
- sideInputsProcessor - Variable in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- SideInputsProcessorFactory - Interface in org.apache.samza.storage
-
- 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
-
- 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
-
- size() - Method in interface org.apache.samza.table.batching.Batch
-
- 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
).
- SqlField(int, String, SqlFieldSchema) - Constructor for class org.apache.samza.sql.schema.SqlSchema.SqlField
-
- SqlFieldSchema - Class in org.apache.samza.sql.schema
-
Schema for the Samza SQL Field.
- SqlSchema - Class in org.apache.samza.sql.schema
-
Representation of SQL schema which is used by Samza SQL.
- SqlSchema(List<String>, List<SqlFieldSchema>) - Constructor for class org.apache.samza.sql.schema.SqlSchema
-
- SqlSchema.SqlField - Class in org.apache.samza.sql.schema
-
- SqlSchemaBuilder - Class in org.apache.samza.sql.schema
-
- start() - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
Perform startup operations.
- start() - Method in interface org.apache.samza.context.ApplicationContainerContext
-
- start() - Method in interface org.apache.samza.context.ApplicationTaskContext
-
- 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.
- Startpoint - Class in org.apache.samza.startpoint
-
Startpoint represents a position in a stream partition.
- StartpointOldest - Class in org.apache.samza.startpoint
-
A
Startpoint
that represents the earliest offset in a stream partition.
- StartpointOldest() - Constructor for class org.apache.samza.startpoint.StartpointOldest
-
Constructs a
Startpoint
that represents the earliest offset in a stream partition.
- StartpointSpecific - Class in org.apache.samza.startpoint
-
A
Startpoint
that represents a specific offset in a stream partition.
- StartpointSpecific(String) - Constructor for class org.apache.samza.startpoint.StartpointSpecific
-
Constructs a
Startpoint
that represents a specific offset in a stream partition.
- StartpointTimestamp - Class in org.apache.samza.startpoint
-
A
Startpoint
that represents a timestamp offset in a stream partition.
- StartpointTimestamp(Long) - Constructor for class org.apache.samza.startpoint.StartpointTimestamp
-
Constructs a
Startpoint
that represents a timestamp offset in a stream partition.
- StartpointUpcoming - Class in org.apache.samza.startpoint
-
A
Startpoint
that represents the latest offset in a stream partition.
- StartpointUpcoming() - Constructor for class org.apache.samza.startpoint.StartpointUpcoming
-
Constructs a
Startpoint
that represents the latest offset in a stream partition.
- StartpointVisitor<IN,OUT> - Interface in org.apache.samza.startpoint
-
- status() - Method in interface org.apache.samza.runtime.ApplicationRunner
-
- statusCode - Variable in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- stop() - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
Perform teardown operations for the Manager.
- stop() - Method in interface org.apache.samza.context.ApplicationContainerContext
-
- stop() - Method in interface org.apache.samza.context.ApplicationTaskContext
-
- 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.
- StorageEngineFactory.StoreMode - Enum in org.apache.samza.storage
-
Enum to describe different modes a
StorageEngine
can be created in.
- STORE_KEY_SERDE - Static variable in class org.apache.samza.config.JavaTableConfig
-
- STORE_MSG_SERDE - Static variable in class org.apache.samza.config.JavaTableConfig
-
- 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
-
- 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
-
- StreamJob - Interface in org.apache.samza.job
-
A StreamJob runs Samza
StreamTask
s in its specific environment.
- StreamJobFactory - Interface in org.apache.samza.job
-
- StreamOperatorTaskFactory - Interface in org.apache.samza.task
-
- 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
-
- 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
-
- SYSTEM_STREAM_NAME_PATTERN - Static variable in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- 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
-
- SystemFactory - Interface in org.apache.samza.system
-
- SystemProducer - Interface in org.apache.samza.system
-
SystemProducers are how Samza writes messages from
StreamTask
s to outside systems,
such as messaging systems like Kafka, or file systems.
- SystemProducerException - Exception in org.apache.samza.system
-
- SystemProducerException(String) - Constructor for exception org.apache.samza.system.SystemProducerException
-
- SystemProducerException(Throwable) - Constructor for exception org.apache.samza.system.SystemProducerException
-
- SystemProducerException(String, Throwable) - Constructor for exception org.apache.samza.system.SystemProducerException
-
- SystemStream - Class in org.apache.samza.system
-
Streams in Samza consist of both the stream name and the system to which the stream belongs.
- SystemStream(String, String) - Constructor for class org.apache.samza.system.SystemStream
-
Constructs a Samza stream object from specified components.
- SystemStream(SystemStream) - Constructor for class org.apache.samza.system.SystemStream
-
Constructs a Samza stream object based upon an existing Samza stream.
- SystemStreamMetadata - Class in org.apache.samza.system
-
SystemAdmins use this class to return useful metadata about a stream's offset
and partition information.
- SystemStreamMetadata(String, Map<Partition, SystemStreamMetadata.SystemStreamPartitionMetadata>) - Constructor for class org.apache.samza.system.SystemStreamMetadata
-
- SystemStreamMetadata.OffsetType - Enum in org.apache.samza.system
-
OffsetType is an enum used to define which offset should be used when
reading from a SystemStreamPartition for the first time.
- SystemStreamMetadata.SystemStreamPartitionMetadata - Class in org.apache.samza.system
-
Provides offset information for a given SystemStreamPartition.
- SystemStreamPartition - Class in org.apache.samza.system
-
- SystemStreamPartition(String, String, Partition) - Constructor for class org.apache.samza.system.SystemStreamPartition
-
Constructs a Samza stream partition object from specified components.
- SystemStreamPartition(SystemStreamPartition) - Constructor for class org.apache.samza.system.SystemStreamPartition
-
Constructs a Samza stream partition object based upon an existing Samza stream partition.
- SystemStreamPartition(SystemStream, Partition) - Constructor for class org.apache.samza.system.SystemStreamPartition
-
Constructs a Samza stream partition object based upon another Samza stream and a specified partition.
- SystemStreamPartitionGrouper - Interface in org.apache.samza.container.grouper.stream
-
Group a set of SystemStreamPartitions into logical taskNames that share a common characteristic, defined
by the implementation.
- SystemStreamPartitionGrouperFactory - Interface in org.apache.samza.container.grouper.stream
-
Return an instance a SystemStreamPartitionGrouper per the particular implementation
- SystemStreamPartitionIterator - Class in org.apache.samza.system
-
- SystemStreamPartitionIterator(SystemConsumer, SystemStreamPartition) - Constructor for class org.apache.samza.system.SystemStreamPartitionIterator
-
- SystemStreamPartitionIterator(SystemConsumer, SystemStreamPartition, int) - Constructor for class org.apache.samza.system.SystemStreamPartitionIterator
-
- SystemStreamPartitionMapper - Interface in org.apache.samza.container.grouper.stream
-
Input streams of a samza job can be either expanded or contracted by the user.
- SystemStreamPartitionMapperFactory - Interface in org.apache.samza.container.grouper.stream
-
- SystemStreamPartitionMatcher - Interface in org.apache.samza.system
-
- SystemStreamPartitionMetadata(String, String, String) - Constructor for class org.apache.samza.system.SystemStreamMetadata.SystemStreamPartitionMetadata
-
- table - Variable in class org.apache.samza.table.remote.BaseTableFunction
-
- Table<R> - Interface in org.apache.samza.table
-
A
Table
is an abstraction for data sources that support random access by key.
- TABLE_ID_PREFIX - Static variable in class org.apache.samza.config.JavaTableConfig
-
- TABLE_PROVIDER_FACTORY - Static variable in class org.apache.samza.config.JavaTableConfig
-
- TABLE_PROVIDER_FACTORY_SUFFIX - Static variable in class org.apache.samza.config.JavaTableConfig
-
- 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
.
- TableFunction - Interface in org.apache.samza.table.remote
-
The root interface for table read and write function.
- tableId - Variable in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
- TablePart - Interface in org.apache.samza.table.remote
-
A building block of a remote table
- TableProvider - Interface in org.apache.samza.table
-
A table provider provides the implementation for a table.
- TableProviderFactory - Interface in org.apache.samza.table
-
Factory of a table provider object
- TableRateLimiter<K,V> - Class in org.apache.samza.table.remote
-
Helper class for remote table to throttle table IO requests with the configured rate limiter.
- TableRateLimiter(String, RateLimiter, TableRateLimiter.CreditFunction<K, V>, String) - Constructor for class org.apache.samza.table.remote.TableRateLimiter
-
- TableRateLimiter.CreditFunction<K,V> - Interface in org.apache.samza.table.remote
-
Function interface for providing rate limiting credits for each table record.
- TableReadFunction<K,V> - Interface in org.apache.samza.table.remote
-
A function object to be used with a remote readable table implementation.
- TableRetryPolicy - Class in org.apache.samza.table.retry
-
Common retry policy parameters for table IO.
- TableRetryPolicy() - Constructor for class org.apache.samza.table.retry.TableRetryPolicy
-
- TableRetryPolicy.RetryPredicate - Interface in org.apache.samza.table.retry
-
Serializable adapter interface for Predicate
.
- TABLES_PREFIX - Static variable in class org.apache.samza.config.JavaTableConfig
-
- TableWriteFunction<K,V> - Interface in org.apache.samza.table.remote
-
A function object to be used with a remote read/write table implementation.
- 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
-
- 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
-
- TaskFactory<T> - Interface in org.apache.samza.task
-
The base interface for all task factories (i.e.
- TaskMode - Enum in org.apache.samza.job.model
-
This defines the logical mode of a taskInstance.
- 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, TaskMode) - Constructor for class org.apache.samza.job.model.TaskModel
-
Create a TaskModel for an active task with the given taskName, SSPs, and changelogPartition.
- TaskModel(TaskName, Set<SystemStreamPartition>, Partition) - Constructor for class org.apache.samza.job.model.TaskModel
-
Create a TaskModel for an active task with the given taskName, SSPs, and changelogPartition.
- TaskName - Class in org.apache.samza.container
-
- TaskName(String) - Constructor for class org.apache.samza.container.TaskName
-
- throttle(K, Object...) - Method in class org.apache.samza.table.remote.TableRateLimiter
-
Throttle a request with a key argument if necessary.
- throttle(K, V, Object...) - Method in class org.apache.samza.table.remote.TableRateLimiter
-
Throttle a request with both the key and value arguments if necessary.
- throttle(int, Object...) - Method in class org.apache.samza.table.remote.TableRateLimiter
-
Throttle a request with opId and associated arguments
- throttle(Collection<K>, Object...) - Method in class org.apache.samza.table.remote.TableRateLimiter
-
Throttle a request with a collection of keys as the argument if necessary.
- throttleRecords(Collection<Entry<K, V>>, Object...) - Method in class org.apache.samza.table.remote.TableRateLimiter
-
Throttle a request with a collection of table records as the argument if necessary.
- 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
-
- 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
-
- timestamp - Variable in class org.apache.samza.container.placement.ContainerPlacementMessage
-
- 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
-
- toConfig(Config) - Method in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
- toConfig(Config) - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- toConfig(Config) - Method in class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
- toConfig(Config) - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
Generate configuration for this table descriptor, the generated configuration
should be the complete configuration for this table that can be directly
included in the job configuration.
- toConfig(Config) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- toConfig(Config) - Method in interface org.apache.samza.table.descriptors.TableDescriptor
-
Generate configuration for this table descriptor, the generated configuration
should be the complete configuration for this table that can be directly
included in the job configuration.
- toConfig(Config, Config) - Method in interface org.apache.samza.table.remote.TablePart
-
Generate configuration for this building block.
- toConfig(Config, Config) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Generate configuration for this building block.
- toJson(String, Object) - Static method in class org.apache.samza.table.utils.SerdeUtils
-
Helper method to serialize Java objects as json strings
- toString() - Method in class org.apache.samza.checkpoint.Checkpoint
-
- toString() - Method in class org.apache.samza.checkpoint.CheckpointedChangelogOffset
-
- toString() - Method in class org.apache.samza.checkpoint.CheckpointId
-
- toString() - Method in class org.apache.samza.config.MapConfig
-
- toString() - Method in class org.apache.samza.container.placement.ContainerPlacementRequestMessage
-
- toString() - Method in class org.apache.samza.container.placement.ContainerPlacementResponseMessage
-
- 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 enum org.apache.samza.job.model.TaskMode
-
- 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.KV
-
- 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.sql.SamzaSqlRelRecord
-
- toString() - Method in class org.apache.samza.startpoint.Startpoint
-
- toString() - Method in class org.apache.samza.startpoint.StartpointOldest
-
- toString() - Method in class org.apache.samza.startpoint.StartpointSpecific
-
- toString() - Method in class org.apache.samza.startpoint.StartpointTimestamp
-
- toString() - Method in class org.apache.samza.startpoint.StartpointUpcoming
-
- 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
-
- Trigger<M> - Interface in org.apache.samza.operators.triggers
-
Marker interface for all triggers.
- Triggers - Class in org.apache.samza.operators.triggers
-
- 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.
- validate(MetricsAccessor) - Method in interface org.apache.samza.metrics.MetricsValidator
-
Validate the metrics values of a job
- validate() - Method in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
Validate that this table descriptor is constructed properly; this method is used internally.
- validate() - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- validate() - Method in class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
- validate() - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- validate() - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- 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.container.placement.ContainerPlacementMessage.StatusCode
-
Returns the enum constant of this type with the specified name.
- 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.job.model.TaskMode
-
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.sql.schema.SamzaSqlFieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.storage.StorageEngineFactory.StoreMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.samza.system.ChangelogSSPIterator.Mode
-
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.container.placement.ContainerPlacementMessage.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.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.job.model.TaskMode
-
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.sql.schema.SamzaSqlFieldType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.storage.StorageEngineFactory.StoreMode
-
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.ChangelogSSPIterator.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.system.MessageType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.system.SystemStreamMetadata.OffsetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.samza.task.TaskCoordinator.RequestScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- visit(MetricsVisitor) - Method in class org.apache.samza.metrics.Counter
-
- visit(MetricsVisitor) - Method in class org.apache.samza.metrics.Gauge
-
- visit(MetricsVisitor) - Method in interface org.apache.samza.metrics.Metric
-
- visit(Metric) - Method in class org.apache.samza.metrics.MetricsVisitor
-
- visit(MetricsVisitor) - Method in class org.apache.samza.metrics.Timer
-
- visit(IN, StartpointSpecific) - Method in interface org.apache.samza.startpoint.StartpointVisitor
-
Performs a sequence of operations using IN and
StartpointSpecific
and returns the result of the execution.
- visit(IN, StartpointTimestamp) - Method in interface org.apache.samza.startpoint.StartpointVisitor
-
Performs a sequence of operations using IN and
StartpointTimestamp
and returns the result of the execution.
- visit(IN, StartpointOldest) - Method in interface org.apache.samza.startpoint.StartpointVisitor
-
Performs a sequence of operations using IN and
StartpointOldest
and returns the result of the execution.
- visit(IN, StartpointUpcoming) - Method in interface org.apache.samza.startpoint.StartpointVisitor
-
Performs a sequence of operations using IN and
StartpointUpcoming
and returns the result of the execution.
- 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
-
- 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
-
- 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
Window
s.
- WindowType - Enum in org.apache.samza.operators.windows.internal
-
- withApplicationContainerContextFactory(ApplicationContainerContextFactory<?>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
-
- withApplicationTaskContextFactory(ApplicationTaskContextFactory<?>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
-
- withAsyncCallbackExecutorPoolSize(int) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Specify the size of the thread pool for the executor used to execute
callbacks of CompletableFutures of async Table operations.
- withBatchProvider(BatchProvider<K, V>) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- withCache(Cache<K, V>) - Method in class org.apache.samza.table.descriptors.GuavaCacheTableDescriptor
-
Specify a pre-configured Guava cache instance to be used for caching table.
- withCacheSize(long) - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Specify the max cache size for size-based eviction.
- withChangelogEnabled() - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
Enable changelog for this table, by default changelog is disabled.
- withChangelogReplicationFactor(int) - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
The property defines the number of replicas to use for the change log stream.
- withChangelogStream(String) - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
Samza stores are local to a container.
- withConfig(String, String) - Method in class org.apache.samza.table.descriptors.BaseTableDescriptor
-
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
-
- withExponentialBackoff(Duration, Duration, double) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set the parameters for the exponential backoff policy.
- withFixedBackoff(Duration) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set the sleepTime time for the fixed backoff policy.
- withInputStream(InputDescriptor) - Method in interface org.apache.samza.application.descriptors.TaskApplicationDescriptor
-
Adds the input stream to the application.
- withJitter(Duration) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set the jitter for the backoff policy to provide additional randomness.
- withMaxBatchDelay(Duration) - Method in class org.apache.samza.table.batching.BatchProvider
-
- withMaxBatchSize(int) - Method in class org.apache.samza.table.batching.BatchProvider
-
- withMetricsReporterFactories(Map<String, MetricsReporterFactory>) - Method in interface org.apache.samza.application.descriptors.ApplicationDescriptor
-
- 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.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
-
- withRandomBackoff(Duration, Duration) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set the sleepTime time for the random backoff policy.
- withRateLimiter(RateLimiter, TableRateLimiter.CreditFunction<K, V>, TableRateLimiter.CreditFunction<K, V>) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Specify a rate limiter along with credit functions to map a table record (as KV) to the amount
of credits to be charged from the rate limiter for table read and write operations.
- withRateLimiterDisabled() - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Disable both read and write rate limiter.
- withReadFunction(TableReadFunction<K, V>) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Use specified TableReadFunction with remote table and a retry policy.
- withReadRateLimit(int) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Specify the rate limit for table read operations.
- withReadRateLimiterDisabled() - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Disable the read rate limiter.
- withReadRetryPolicy(TableRetryPolicy) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- withReadTtl(Duration) - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Specify the TTL for each read access, ie.
- withRetryPredicate(TableRetryPolicy.RetryPredicate) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set the predicate to use for identifying retriable exceptions.
- withSideInputs(List<String>) - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
Add side inputs to the table.
- withSideInputsProcessor(SideInputsProcessor) - Method in class org.apache.samza.table.descriptors.LocalTableDescriptor
-
- withStopAfterAttempts(int) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set maximum number of attempts before terminating the operation.
- withStopAfterDelay(Duration) - Method in class org.apache.samza.table.retry.TableRetryPolicy
-
Set maximum total delay (sleepTime + execution) before terminating the operation.
- 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
-
- withTaskFactory(TaskFactory) - Method in interface org.apache.samza.application.descriptors.TaskApplicationDescriptor
-
- withWriteAround() - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Specify if write-around policy should be used to bypass writing
to cache for put operations.
- withWriteFunction(TableWriteFunction<K, V>) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Use specified TableWriteFunction with remote table and a retry policy.
- withWriteRateLimit(int) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Specify the rate limit for table write operations.
- withWriteRateLimiterDisabled() - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
Disable the write rate limiter.
- withWriteRetryPolicy(TableRetryPolicy) - Method in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- withWriteTtl(Duration) - Method in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
Specify the TTL for each write access, ie.
- write(int, Object...) - Method in interface org.apache.samza.table.ReadWriteTable
-
Executes a write operation.
- WRITE_AROUND - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- WRITE_CREDIT_FN - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- WRITE_FN - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- WRITE_RETRY_POLICY - Static variable in class org.apache.samza.table.descriptors.RemoteTableDescriptor
-
- WRITE_TTL_MS - Static variable in class org.apache.samza.table.descriptors.CachingTableDescriptor
-
- writeAsync(int, Object...) - Method in interface org.apache.samza.table.AsyncReadWriteTable
-
Asynchronously executes a write operation.
- writeAsync(int, Object...) - Method in interface org.apache.samza.table.remote.TableWriteFunction
-
Asynchronously write data to table for specified opId
and additional arguments.
- writeCheckpoint(TaskName, Checkpoint) - Method in interface org.apache.samza.checkpoint.CheckpointManager
-
Writes a checkpoint based on the current state of a Samza stream partition.