A B C D E F G H I K L M N O P Q R S T U V Z

A

AbstractSlidingWindowPE<T extends Slot<U>,U,V> - Class in org.apache.s4.core.window
Abstract ProcessingElement that can store historical values using a sliding window.
AbstractSlidingWindowPE(App, int, long, SlotFactory<T>) - Constructor for class org.apache.s4.core.window.AbstractSlidingWindowPE
Constructor for the event-based slot.
AbstractSlidingWindowPE(App, long, TimeUnit, int, SlotFactory<T>) - Constructor for class org.apache.s4.core.window.AbstractSlidingWindowPE
Constructor for time-based slots.
AdapterApp - Class in org.apache.s4.core.adapter
Base class for adapters.
AdapterApp() - Constructor for class org.apache.s4.core.adapter.AdapterApp
 
addInputStream(int, String, String) - Method in class org.apache.s4.comm.topology.RemoteStreams
Publishes interest in a stream from an application.
addListener(ClusterChangeListener) - Method in interface org.apache.s4.comm.topology.Cluster
 
addListener(ClusterChangeListener) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
addNode(ClusterNode) - Method in class org.apache.s4.comm.topology.PhysicalCluster
 
addOutputStream(String, String, String) - Method in class org.apache.s4.comm.topology.RemoteStreams
 
addSlot() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
Add a slot to the sliding window.
addStream(Streamable<Event>) - Method in class org.apache.s4.core.App
 
App - Class in org.apache.s4.core
Container base class to hold all processing elements.
App() - Constructor for class org.apache.s4.core.App
 
app - Variable in class org.apache.s4.core.ProcessingElement
 
App.ClockType - Enum in org.apache.s4.core
The internal clock can be configured as "wall clock" or "event clock".
assignClusterNode() - Method in interface org.apache.s4.comm.topology.Assignment
 
assignClusterNode() - Method in class org.apache.s4.comm.topology.AssignmentFromZK
 
Assignment - Interface in org.apache.s4.comm.topology
Upon startup an S4 process in a cluster must be assigned one and only one of the available cluster nodes.
AssignmentFromZK - Class in org.apache.s4.comm.topology
Handles partition assignment through Zookeeper.
AssignmentFromZK(String, String, int, int) - Constructor for class org.apache.s4.comm.topology.AssignmentFromZK
 

B

build() - Method in class org.apache.s4.core.ft.CheckpointingConfig.Builder
 

C

call() - Method in class org.apache.s4.core.ft.FetchTask
 
call() - Method in class org.apache.s4.core.ft.SerializeTask
 
channelClosed(ChannelHandlerContext, ChannelStateEvent) - Method in class org.apache.s4.comm.tcp.TCPListener.ChannelHandler
 
checkAndSendIfNotLocal(String, Event) - Method in class org.apache.s4.core.Sender
This method attempts to send an event to a remote partition.
checkpoint() - Method in class org.apache.s4.core.ProcessingElement
 
CheckpointId - Class in org.apache.s4.core.ft
Identifier of PEs.
CheckpointId() - Constructor for class org.apache.s4.core.ft.CheckpointId
 
CheckpointId(ProcessingElement) - Constructor for class org.apache.s4.core.ft.CheckpointId
 
CheckpointId(String, String) - Constructor for class org.apache.s4.core.ft.CheckpointId
 
CheckpointId(String) - Constructor for class org.apache.s4.core.ft.CheckpointId
 
CheckpointingConfig - Class in org.apache.s4.core.ft
Checkpointing configuration: event count based vs time interval, frequency.
CheckpointingConfig.Builder - Class in org.apache.s4.core.ft
 
CheckpointingConfig.Builder(CheckpointingConfig.CheckpointingMode) - Constructor for class org.apache.s4.core.ft.CheckpointingConfig.Builder
 
CheckpointingConfig.CheckpointingMode - Enum in org.apache.s4.core.ft
Identifies the kind of checkpointing: time based, event count, or no checkpointing
CheckpointingFramework - Interface in org.apache.s4.core.ft
This interface defines the functionalities offered by the checkpointing framework.
CheckpointingFramework.StorageResultCode - Enum in org.apache.s4.core.ft
 
CheckpointingTask - Class in org.apache.s4.core.ft
When checkpointing at regular time intervals, this class is used to actually perform the checkpoints.
CheckpointingTask(ProcessingElement) - Constructor for class org.apache.s4.core.ft.CheckpointingTask
 
checkStorageDir() - Method in class org.apache.s4.core.ft.DefaultFileSystemStateStorage
 
clean(String, String) - Method in class org.apache.s4.comm.tools.TaskSetup
 
clean(String) - Method in class org.apache.s4.comm.tools.TaskSetup
 
clearDirty() - Method in class org.apache.s4.core.ProcessingElement
Dirty state is cleared after the PE has been serialized.
clone() - Method in class org.apache.s4.core.ProcessingElement
This method exists simply to make clone() protected.
close() - Method in interface org.apache.s4.base.Emitter
 
close() - Method in interface org.apache.s4.base.Listener
 
close() - Method in class org.apache.s4.comm.tcp.TCPEmitter
 
close() - Method in class org.apache.s4.comm.tcp.TCPListener
 
close() - Method in class org.apache.s4.comm.udp.UDPEmitter
 
close() - Method in class org.apache.s4.comm.udp.UDPListener
 
close() - Method in class org.apache.s4.core.App
 
close() - Method in class org.apache.s4.core.ProcessingElement
 
close() - Method in class org.apache.s4.core.Receiver
 
close() - Method in class org.apache.s4.core.RemoteStream
 
close() - Method in class org.apache.s4.core.Stream
Stop and close this stream.
close() - Method in interface org.apache.s4.core.Streamable
Stop and close all the streams.
close() - Method in class org.apache.s4.core.window.DefaultAggregatingSlot
 
close() - Method in class org.apache.s4.core.window.OHCLSlot
 
close() - Method in interface org.apache.s4.core.window.Slot
Compute aggregated data on available gathered slot data, place slot and slot data in immutable state.
Cluster - Interface in org.apache.s4.comm.topology
Represents a logical cluster
ClusterChangeListener - Interface in org.apache.s4.comm.topology
Entities interested in changes occurring in topologies implement this listener and should register through the Cluster interface
ClusterFromZK - Class in org.apache.s4.comm.topology
Represents a logical cluster definition fetched from Zookeeper.
ClusterFromZK(String, String, int, int) - Constructor for class org.apache.s4.comm.topology.ClusterFromZK
only the local topology
ClusterFromZK(String, ZkClient, String) - Constructor for class org.apache.s4.comm.topology.ClusterFromZK
any topology
ClusterNode - Class in org.apache.s4.comm.topology
Represents an node.
ClusterNode(int, int, String, String) - Constructor for class org.apache.s4.comm.topology.ClusterNode
 
Clusters - Interface in org.apache.s4.comm.topology
Represents clusters related to the current node (clusters to which this node belongs, and connected clusters that may receive messages from this node)
ClustersFromZK - Class in org.apache.s4.comm.topology
Monitors all clusters
ClustersFromZK(String, String, int, int) - Constructor for class org.apache.s4.comm.topology.ClustersFromZK
 
configure() - Method in class org.apache.s4.comm.DefaultCommModule
 
configure() - Method in class org.apache.s4.core.DefaultCoreModule
 
configure() - Method in class org.apache.s4.core.ft.FileSystemBackendCheckpointingModule
 
configure() - Method in class org.apache.s4.core.util.ParametersInjectionModule
 
containsKey(String) - Method in class org.apache.s4.base.Event
 
convert(String) - Method in class org.apache.s4.core.Main.InlineConfigParameterConverter
 
convert(String) - Method in class org.apache.s4.tools.S4ArgsBase.GradleOptsConverter
 
convert(String) - Method in class org.apache.s4.tools.ZKServer.ClusterConfigsConverter
 
CreateApp - Class in org.apache.s4.tools
 
CreateApp() - Constructor for class org.apache.s4.tools.CreateApp
 
createInputStream(String, KeyFinder<T>, ProcessingElement...) - Method in class org.apache.s4.core.App
Creaters an "input" stream, i.e.
createInputStream(String, ProcessingElement...) - Method in class org.apache.s4.core.App
 
createOutputStream(String, KeyFinder<Event>) - Method in class org.apache.s4.core.App
Creates a "remote" stream, i.e.
createOutputStream(String) - Method in class org.apache.s4.core.App
 
createPE(Class<T>, String) - Method in class org.apache.s4.core.App
Creates a ProcessingElement prototype.
createPE(Class<T>) - Method in class org.apache.s4.core.App
Creates a ProcessingElement prototype.
createRemoteEmitter(Cluster) - Method in interface org.apache.s4.comm.RemoteEmitterFactory
 
createS4RLoader(String) - Method in class org.apache.s4.base.util.S4RLoaderFactory
Explodes the s4r archive in a subdirectory of a user specified directory through "s4.tmp.dir" parameter, and prepares a classloader that will load classes and resources from, first, the application classes, then the dependencies.
createSlidingWindowPE(Class<T>, long, TimeUnit, int, SlotFactory) - Method in class org.apache.s4.core.App
 
createSlot() - Method in class org.apache.s4.core.window.DefaultAggregatingSlot.DefaultAggregatingSlotFactory
 
createSlot() - Method in class org.apache.s4.core.window.OHCLSlot.OHCLSlotFactory
 
createSlot() - Method in interface org.apache.s4.core.window.SlotFactory
 
createStorageCallback() - Method in class org.apache.s4.core.ft.LoggingStorageCallbackFactory
 
createStorageCallback() - Method in interface org.apache.s4.core.ft.StorageCallbackFactory
Factory method
createStream(String, KeyFinder<T>, Class<T>, ProcessingElement...) - Method in class org.apache.s4.core.App
Creates a stream with a specific key finder.
createStream(String, KeyFinder<T>, ProcessingElement...) - Method in class org.apache.s4.core.App
 
createStream(String, ProcessingElement...) - Method in class org.apache.s4.core.App
 
createStream(Class<T>) - Method in class org.apache.s4.core.App
 

D

DefaultAggregatingSlot<T> - Class in org.apache.s4.core.window
Window slot that keeps all data elements as a list.
DefaultAggregatingSlot() - Constructor for class org.apache.s4.core.window.DefaultAggregatingSlot
 
DefaultAggregatingSlot.DefaultAggregatingSlotFactory<T> - Class in org.apache.s4.core.window
 
DefaultAggregatingSlot.DefaultAggregatingSlotFactory() - Constructor for class org.apache.s4.core.window.DefaultAggregatingSlot.DefaultAggregatingSlotFactory
 
DefaultCommModule - Class in org.apache.s4.comm
Default configuration module for the communication layer.
DefaultCommModule(InputStream, String) - Constructor for class org.apache.s4.comm.DefaultCommModule
 
DefaultCoreModule - Class in org.apache.s4.core
Temporary module allowing assignment from ZK, communication through Netty, and distributed deployment management, until we have a better way to customize node configuration
DefaultCoreModule(InputStream) - Constructor for class org.apache.s4.core.DefaultCoreModule
 
DefaultFileSystemStateStorage - Class in org.apache.s4.core.ft
Implementation of a file system backend storage to persist checkpoints.
DefaultFileSystemStateStorage() - Constructor for class org.apache.s4.core.ft.DefaultFileSystemStateStorage
 
DefaultHasher - Class in org.apache.s4.comm
Simple hasher implementation.
DefaultHasher() - Constructor for class org.apache.s4.comm.DefaultHasher
 
DefineCluster - Class in org.apache.s4.tools
 
DefineCluster() - Constructor for class org.apache.s4.tools.DefineCluster
 
Deploy - Class in org.apache.s4.tools
 
Deploy() - Constructor for class org.apache.s4.tools.Deploy
 
deployApplication() - Method in class org.apache.s4.deploy.DistributedDeploymentManager
 
DeploymentFailedException - Exception in org.apache.s4.deploy
Indicates that an application failed to be deployed to an S4 node.
DeploymentFailedException(String, Throwable) - Constructor for exception org.apache.s4.deploy.DeploymentFailedException
 
DeploymentFailedException(String) - Constructor for exception org.apache.s4.deploy.DeploymentFailedException
 
DeploymentManager - Interface in org.apache.s4.deploy
Marker interface for deployment managers.
deserialize(byte[]) - Method in interface org.apache.s4.base.SerializerDeserializer
 
deserialize(byte[]) - Method in class org.apache.s4.comm.serialize.KryoSerDeser
 
deserialize(byte[]) - Method in class org.apache.s4.comm.topology.ZNRecordSerializer
 
deserializeState(byte[]) - Method in class org.apache.s4.core.ProcessingElement
 
disconnect() - Method in class org.apache.s4.comm.tools.TaskSetup
 
dispatchEvent(ProcessingElement, Event) - Method in interface org.apache.s4.core.gen.OverloadDispatcher
 
dispatchTrigger(ProcessingElement, Event) - Method in interface org.apache.s4.core.gen.OverloadDispatcher
 
DistributedDeploymentManager - Class in org.apache.s4.deploy
Monitors application availability on a given s4 cluster.
DistributedDeploymentManager(String, String, int, int, Server) - Constructor for class org.apache.s4.deploy.DistributedDeploymentManager
 

E

emit(T, Stream<T>[]) - Method in class org.apache.s4.core.ProcessingElement
Helper method to be used by PE implementation classes.
Emitter - Interface in org.apache.s4.base
Defines an event emitter, responsible for sending an event to a given partition of the cluster.
equals(Object) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
equals(Object) - Method in class org.apache.s4.comm.topology.StreamConsumer
 
equals(Object) - Method in class org.apache.s4.comm.topology.ZNRecord
 
equals(Object) - Method in class org.apache.s4.core.ft.CheckpointId
 
evaluateWindow(Collection<T>) - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
User provided function that evaluates the whole content of the window.
Event - Class in org.apache.s4.base
The base event class in S4.
Event() - Constructor for class org.apache.s4.base.Event
Default constructor sets time using system time.
Event(long) - Constructor for class org.apache.s4.base.Event
This constructor explicitly sets the time.
EventMessage - Class in org.apache.s4.base
Encapsulates application-level events of type Event.
EventMessage() - Constructor for class org.apache.s4.base.EventMessage
 
EventMessage(String, String, byte[]) - Constructor for class org.apache.s4.base.EventMessage
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.apache.s4.comm.tcp.TCPListener.ChannelHandler
 

F

fetch(URI) - Method in class org.apache.s4.deploy.FileSystemS4RFetcher
 
fetch(URI) - Method in class org.apache.s4.deploy.HttpS4RFetcher
 
fetch(URI) - Method in interface org.apache.s4.deploy.S4RFetcher
Returns a stream to an S4R archive file
fetchS4App(URI) - Method in class org.apache.s4.deploy.DistributedDeploymentManager
 
fetchSerializedState(CheckpointId) - Method in interface org.apache.s4.core.ft.CheckpointingFramework
Fetches checkpoint data from storage for a given PE
fetchSerializedState(CheckpointId) - Method in class org.apache.s4.core.ft.NoOpCheckpointingFramework
 
fetchSerializedState(CheckpointId) - Method in class org.apache.s4.core.ft.SafeKeeper
 
fetchState(CheckpointId) - Method in class org.apache.s4.core.ft.DefaultFileSystemStateStorage
 
fetchState(CheckpointId) - Method in interface org.apache.s4.core.ft.StateStorage
Fetches data for a stored checkpoint.
fetchStoredKeys() - Method in class org.apache.s4.core.ft.DefaultFileSystemStateStorage
 
fetchStoredKeys() - Method in interface org.apache.s4.core.ft.StateStorage
Fetches all stored safeKeeper Ids.
FetchTask - Class in org.apache.s4.core.ft
Encapsulates a checkpoint fetching operation.
FetchTask(StateStorage, CheckpointId) - Constructor for class org.apache.s4.core.ft.FetchTask
 
FileExistsValidator - Class in org.apache.s4.tools
 
FileExistsValidator() - Constructor for class org.apache.s4.tools.FileExistsValidator
 
FileSystemBackendCheckpointingModule - Class in org.apache.s4.core.ft
Checkpointing module that uses the DefaultFileSystemStateStorage as a checkpointing backend.
FileSystemBackendCheckpointingModule() - Constructor for class org.apache.s4.core.ft.FileSystemBackendCheckpointingModule
 
FileSystemS4RFetcher - Class in org.apache.s4.deploy
Fetches S4R files from a file system, possibly distributed.
FileSystemS4RFetcher() - Constructor for class org.apache.s4.deploy.FileSystemS4RFetcher
 
frequency(int) - Method in class org.apache.s4.core.ft.CheckpointingConfig.Builder
 
frequency - Variable in class org.apache.s4.core.ft.CheckpointingConfig
 

G

generate() - Method in class org.apache.s4.core.gen.OverloadDispatcherGenerator
 
GenericKeyFinder<T extends Event> - Class in org.apache.s4.base
Use introspection on the target Event to create the key finder.
GenericKeyFinder(String, Class<T>) - Constructor for class org.apache.s4.base.GenericKeyFinder
 
get(String, Class<T>) - Method in class org.apache.s4.base.Event
Get value for key.
get(String) - Method in class org.apache.s4.base.Event
Returns the value for key as a String.
get(T) - Method in class org.apache.s4.base.GenericKeyFinder
 
get(T) - Method in class org.apache.s4.base.Key
 
get(T) - Method in interface org.apache.s4.base.KeyFinder
 
get(T) - Method in class org.apache.s4.core.Key
 
getAggregatedData() - Method in class org.apache.s4.core.window.DefaultAggregatingSlot
 
getApp() - Method in class org.apache.s4.core.ProcessingElement
PE objects must be associated with one and only one App object.
getApp() - Method in class org.apache.s4.core.Stream
 
getAppId() - Method in class org.apache.s4.base.Event
All events must be assigned the unique App ID of the App that owns the stream to which this event is injected.
getAppId() - Method in class org.apache.s4.comm.topology.StreamConsumer
 
getAppName() - Method in class org.apache.s4.base.EventMessage
 
getAttributesAsMap() - Method in class org.apache.s4.base.Event
 
getCheckpointingConfig() - Method in class org.apache.s4.core.ProcessingElement
 
getCheckpointingFramework() - Method in class org.apache.s4.core.App
 
getClockType() - Method in class org.apache.s4.core.App
 
getCluster(String) - Method in interface org.apache.s4.comm.topology.Clusters
 
getCluster(String) - Method in class org.apache.s4.comm.topology.ClustersFromZK
 
getClusterName() - Method in class org.apache.s4.comm.topology.StreamConsumer
 
getCollectionName() - Method in enum org.apache.s4.comm.topology.RemoteStreams.StreamType
 
getConnection() - Method in class org.apache.s4.comm.topology.ZkClient
 
getConsumers(String) - Method in class org.apache.s4.comm.topology.RemoteStreams
 
getEmitter(Cluster) - Method in class org.apache.s4.comm.tcp.RemoteEmitters
 
getEventCount() - Method in class org.apache.s4.core.ProcessingElement
 
getId() - Method in class org.apache.s4.comm.topology.ZNRecord
 
getId() - Method in class org.apache.s4.core.App
 
getId() - Method in class org.apache.s4.core.ProcessingElement
Unique ID for a PE instance.
getInstanceForKey(String) - Method in class org.apache.s4.core.ProcessingElement
This method is designed to be used within the package.
getInstances() - Method in class org.apache.s4.core.ProcessingElement
Get all the local instances.
getKey() - Method in class org.apache.s4.core.ft.CheckpointId
 
getKey() - Method in class org.apache.s4.core.Stream
 
getList(T) - Method in class org.apache.s4.base.Key
 
getList(T) - Method in class org.apache.s4.core.Key
 
getListField(String) - Method in class org.apache.s4.comm.topology.ZNRecord
 
getMachineName() - Method in class org.apache.s4.comm.topology.ClusterNode
 
getMapField(String) - Method in class org.apache.s4.comm.topology.ZNRecord
 
getMessageDropInQueueCount() - Method in class org.apache.s4.comm.udp.UDPEmitter
 
getName() - Method in class org.apache.s4.comm.topology.PhysicalCluster
 
getName() - Method in class org.apache.s4.core.ProcessingElement
 
getName() - Method in class org.apache.s4.core.RemoteStream
 
getName() - Method in class org.apache.s4.core.Stream
 
getName() - Method in interface org.apache.s4.core.Streamable
 
getNodes() - Method in class org.apache.s4.comm.topology.PhysicalCluster
 
getNumPEInstances() - Method in class org.apache.s4.core.ProcessingElement
Returns the approximate number of PE instances from the cache.
getOldestSlot() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 
getOpenSlot() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 
getPartition() - Method in class org.apache.s4.comm.topology.ClusterNode
 
getPartitionCount() - Method in interface org.apache.s4.base.Emitter
 
getPartitionCount() - Method in class org.apache.s4.comm.tcp.TCPEmitter
 
getPartitionCount() - Method in class org.apache.s4.comm.topology.PhysicalCluster
 
getPartitionCount() - Method in class org.apache.s4.comm.udp.UDPEmitter
 
getPartitionId() - Method in interface org.apache.s4.base.Listener
 
getPartitionId() - Method in class org.apache.s4.comm.tcp.TCPListener
 
getPartitionId() - Method in class org.apache.s4.comm.udp.UDPListener
 
getPath(String) - Method in enum org.apache.s4.comm.topology.RemoteStreams.StreamType
 
getPE(String) - Method in class org.apache.s4.core.App
 
getPEInstances() - Method in class org.apache.s4.core.ProcessingElement
 
getPhysicalCluster() - Method in interface org.apache.s4.comm.topology.Cluster
 
getPhysicalCluster() - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
getPort() - Method in class org.apache.s4.comm.topology.ClusterNode
 
getPrototype() - Method in class org.apache.s4.core.ProcessingElement
The ProcessingElement prototype for this object.
getPrototypeId() - Method in class org.apache.s4.core.ft.CheckpointId
 
getReceiver() - Method in class org.apache.s4.core.App
 
getReceiver() - Method in class org.apache.s4.core.Stream
 
getRemoteInstances() - Method in class org.apache.s4.core.ProcessingElement
This method returns an immutable map that contains all the PE instances for this prototype.
getRemoteInstancesForKey() - Method in class org.apache.s4.core.ProcessingElement
This method returns a remote PE instance for key.
getRemoteStream() - Method in class org.apache.s4.core.adapter.AdapterApp
 
getSender() - Method in class org.apache.s4.core.App
 
getSender() - Method in class org.apache.s4.core.Stream
 
getSerDeser() - Method in class org.apache.s4.core.App
 
getSerializedEvent() - Method in class org.apache.s4.base.EventMessage
 
getSessionId() - Method in class org.apache.s4.comm.topology.ZkClient
 
getSimpleField(String) - Method in class org.apache.s4.comm.topology.ZNRecord
 
getSlots() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 
getStat(String) - Method in class org.apache.s4.comm.topology.ZkClient
 
getStreamName() - Method in class org.apache.s4.base.Event
The stream id is used to identify streams uniquely in a cluster configuration.
getStreamName() - Method in class org.apache.s4.base.EventMessage
 
getStreams() - Method in class org.apache.s4.core.App
 
getStringRepresentation() - Method in class org.apache.s4.core.ft.CheckpointId
 
getTargetPEs() - Method in class org.apache.s4.core.Stream
 
getTaskId() - Method in class org.apache.s4.comm.topology.ClusterNode
 
getTime() - Method in class org.apache.s4.base.Event
 
getTime() - Method in class org.apache.s4.core.App
The internal clock is configured as "wall clock" or "event clock" when this object is created.
getTime(TimeUnit) - Method in class org.apache.s4.core.App
The internal clock is configured as "wall clock" or "event clock" when this object is created.
getTimerInterval(TimeUnit) - Method in class org.apache.s4.core.ProcessingElement
The duration of the periodic task controlled by the embedded timer.

H

handleChildChange(String, List<String>) - Method in class org.apache.s4.comm.topology.AssignmentFromZK
 
handleChildChange(String, List<String>) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
handleChildChange(String, List<String>) - Method in class org.apache.s4.comm.topology.RemoteStreams
 
handleDataChange(String, Object) - Method in class org.apache.s4.comm.topology.AssignmentFromZK
 
handleDataChange(String, Object) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
handleDataDeleted(String) - Method in class org.apache.s4.comm.topology.AssignmentFromZK
 
handleDataDeleted(String) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
handleInputEvent(Event) - Method in class org.apache.s4.core.ProcessingElement
 
handleNewSession() - Method in class org.apache.s4.comm.topology.AssignmentFromZK
 
handleNewSession() - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
handleNewSession() - Method in class org.apache.s4.comm.topology.ClustersFromZK
 
handleNewSession() - Method in class org.apache.s4.comm.topology.RemoteStreams
 
handleStateChanged(Watcher.Event.KeeperState) - Method in class org.apache.s4.comm.topology.AssignmentFromZK
 
handleStateChanged(Watcher.Event.KeeperState) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
handleStateChanged(Watcher.Event.KeeperState) - Method in class org.apache.s4.comm.topology.ClustersFromZK
 
handleStateChanged(Watcher.Event.KeeperState) - Method in class org.apache.s4.comm.topology.RemoteStreams
 
hasAttributes() - Method in class org.apache.s4.base.Event
 
hash(String) - Method in interface org.apache.s4.base.Hasher
 
hash(String) - Method in class org.apache.s4.comm.DefaultHasher
 
hashCode() - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
hashCode() - Method in class org.apache.s4.comm.topology.StreamConsumer
 
hashCode() - Method in class org.apache.s4.comm.topology.ZNRecord
 
hashCode() - Method in class org.apache.s4.core.ft.CheckpointId
 
Hasher - Interface in org.apache.s4.base
Defines a transformation between a key and a hashcode.
HttpS4RFetcher - Class in org.apache.s4.deploy
Fetches S4R archive through HTTP.
HttpS4RFetcher() - Constructor for class org.apache.s4.deploy.HttpS4RFetcher
 

I

id - Variable in class org.apache.s4.core.ProcessingElement
 
init() - Method in class org.apache.s4.core.App
 
init() - Method in class org.apache.s4.core.ft.DefaultFileSystemStateStorage
Called by the dependency injection framework, after construction.
initPEPrototypeInternal() - Method in class org.apache.s4.core.ProcessingElement
 
initPEPrototypeInternal() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 
isCheckpointable(ProcessingElement) - Method in interface org.apache.s4.core.ft.CheckpointingFramework
Evaluates whether specified PE should be checkpointed, based on: whether checkpointing enabled whether the pe is "dirty" the checkpointing frequency settings This is used for count-based checkpointing intervals.
isCheckpointable(ProcessingElement) - Method in class org.apache.s4.core.ft.NoOpCheckpointingFramework
 
isCheckpointable(ProcessingElement) - Method in class org.apache.s4.core.ft.SafeKeeper
 
isCheckpointable() - Method in class org.apache.s4.core.ProcessingElement
 
isDirty() - Method in class org.apache.s4.core.ProcessingElement
By default, the state of a PE instance is considered dirty whenever it processed an event.
isSingleton() - Method in class org.apache.s4.core.ProcessingElement
 
isThreadSafe() - Method in class org.apache.s4.core.ProcessingElement
Set to true if the concrete PE class has the ThreadSafe annotation.

K

Key<T extends Event> - Class in org.apache.s4.base
The Key class is used to get the value of the key on a specific type of event.
Key(KeyFinder<T>, String) - Constructor for class org.apache.s4.base.Key
 
Key<T extends Event> - Class in org.apache.s4.core
The Key class is used to get the value of the key on a specific type of event.
Key(KeyFinder<T>, String) - Constructor for class org.apache.s4.core.Key
 
key - Variable in class org.apache.s4.core.RemoteStream
 
key - Variable in class org.apache.s4.core.Stream
 
KeyFinder<T extends Event> - Interface in org.apache.s4.base
The KeyFinder returns a list with one or more String values (One value for single keys, and more than one value for composite keys.)
KryoSerDeser - Class in org.apache.s4.comm.serialize
Serializazer/deserializer based on kryo
KryoSerDeser() - Constructor for class org.apache.s4.comm.serialize.KryoSerDeser
 
KryoSerDeser(ClassLoader) - Constructor for class org.apache.s4.comm.serialize.KryoSerDeser
 

L

Listener - Interface in org.apache.s4.base
Get a byte array received by a lower level layer.
loadApp(File, String) - Method in class org.apache.s4.core.Server
 
loadGeneratedClass(String, byte[]) - Method in class org.apache.s4.base.util.S4RLoader
 
LoggingStorageCallbackFactory - Class in org.apache.s4.core.ft
A factory for creating storage callbacks that simply log callback results
LoggingStorageCallbackFactory() - Constructor for class org.apache.s4.core.ft.LoggingStorageCallbackFactory
 

M

Main - Class in org.apache.s4.core
Bootstrap class for S4.
Main() - Constructor for class org.apache.s4.core.Main
 
main(String[]) - Static method in class org.apache.s4.core.Main
Starts an S4 server.
main(String[]) - Static method in class org.apache.s4.tools.CreateApp
 
main(String[]) - Static method in class org.apache.s4.tools.DefineCluster
 
main(String[]) - Static method in class org.apache.s4.tools.Deploy
 
main(String[]) - Static method in class org.apache.s4.tools.Package
 
main(String[]) - Static method in class org.apache.s4.tools.Status
 
main(String[]) - Static method in class org.apache.s4.tools.Tools
 
main(String[]) - Static method in class org.apache.s4.tools.ZKServer
 
Main.InlineConfigParameterConverter - Class in org.apache.s4.core
Parameters parsing utility.
Main.InlineConfigParameterConverter() - Constructor for class org.apache.s4.core.Main.InlineConfigParameterConverter
 
Main.MainArgs - Class in org.apache.s4.core
Defines command parameters.
Main.MainArgs() - Constructor for class org.apache.s4.core.Main.MainArgs
 
MANIFEST_S4_APP_CLASS - Static variable in class org.apache.s4.core.Server
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.s4.comm.tcp.TCPListener.ChannelHandler
 
mode - Variable in class org.apache.s4.core.ft.CheckpointingConfig
 

N

NoOpCheckpointingFramework - Class in org.apache.s4.core.ft
Implementation of CheckpointingFramework that does NO checkpointing.
NoOpCheckpointingFramework() - Constructor for class org.apache.s4.core.ft.NoOpCheckpointingFramework
 
NoOpDeploymentManager - Class in org.apache.s4.deploy
Does not handle any deployment (hence does not require any cluster configuration settings)
NoOpDeploymentManager() - Constructor for class org.apache.s4.deploy.NoOpDeploymentManager
 

O

OHCLSlot - Class in org.apache.s4.core.window
 
OHCLSlot() - Constructor for class org.apache.s4.core.window.OHCLSlot
 
OHCLSlot.OHCLSlotFactory - Class in org.apache.s4.core.window
 
OHCLSlot.OHCLSlotFactory() - Constructor for class org.apache.s4.core.window.OHCLSlot.OHCLSlotFactory
 
onChange() - Method in class org.apache.s4.comm.tcp.TCPEmitter
 
onChange() - Method in interface org.apache.s4.comm.topology.ClusterChangeListener
 
onChange() - Method in class org.apache.s4.comm.udp.UDPEmitter
 
onClose() - Method in class org.apache.s4.core.adapter.AdapterApp
 
onClose() - Method in class org.apache.s4.core.App
This method is called by the container before unloading the application.
onCreate() - Method in class org.apache.s4.core.ProcessingElement
This method is called after a PE instance is created.
onCreate() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 
onInit() - Method in class org.apache.s4.core.adapter.AdapterApp
 
onInit() - Method in class org.apache.s4.core.App
This method is called by the container to initialize applications.
onRemove() - Method in class org.apache.s4.core.ProcessingElement
This method is called before a PE instance is removed.
onRemove() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 
onStart() - Method in class org.apache.s4.core.adapter.AdapterApp
 
onStart() - Method in class org.apache.s4.core.App
 
onTime() - Method in class org.apache.s4.core.ProcessingElement
This method is called by the PE timer.
onTrigger(Event) - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
For count-based windows, we use a trigger that adds a new slot when the current one reaches its maximum capacity.
org.apache.s4.base - package org.apache.s4.base
Defines some of the basic elements of the S4 platforms.
org.apache.s4.base.util - package org.apache.s4.base.util
Utility classes, mostly related to classloading.
org.apache.s4.comm - package org.apache.s4.comm
This package and subpackages define mechanisms for low-level communications in the S4 platform.
org.apache.s4.comm.serialize - package org.apache.s4.comm.serialize
Serialization utilities for messages and PEs.
org.apache.s4.comm.tcp - package org.apache.s4.comm.tcp
TCP-based communication layer implementation.
org.apache.s4.comm.tools - package org.apache.s4.comm.tools
Utility classes.
org.apache.s4.comm.topology - package org.apache.s4.comm.topology
Clusters configurations and partitions assignments to cluster nodes through Zookeeper.
org.apache.s4.comm.udp - package org.apache.s4.comm.udp
UDP-based implementation of the communication layer.
org.apache.s4.core - package org.apache.s4.core
Key classes of the S4 platform, implementing concepts such as Stream, Processing Element.
org.apache.s4.core.adapter - package org.apache.s4.core.adapter
This package contains utilities for creating and configuring adapter apps.
org.apache.s4.core.ft - package org.apache.s4.core.ft
This package contains classes for providing some fault tolerance to S4 PEs.
org.apache.s4.core.gen - package org.apache.s4.core.gen
Utility classes for dynamic code generation, in particular proxies to enable dispatching of events to methods of processing elements based on the runtime type of the event.
org.apache.s4.core.util - package org.apache.s4.core.util
Utility classes.
org.apache.s4.core.window - package org.apache.s4.core.window
Provides facilities for processing events as samples, through time or count-based windows.
org.apache.s4.deploy - package org.apache.s4.deploy
Dynamic application deployment framework, that allows identifying new available applications, downloading them through various protocols, loading them and starting them in the current S4 node.
org.apache.s4.tools - package org.apache.s4.tools
Implementations of S4-related commands.
OverloadDispatcher - Interface in org.apache.s4.core.gen
This interface defines methods for dispatching input and output events to the most relevant methods of the processing elements.
OverloadDispatcherGenerator - Class in org.apache.s4.core.gen
This class generates a proxy to enable dispatching of events to methods of processing elements based on the runtime type of the event.
OverloadDispatcherGenerator() - Constructor for class org.apache.s4.core.gen.OverloadDispatcherGenerator
 
OverloadDispatcherGenerator(Class<?>) - Constructor for class org.apache.s4.core.gen.OverloadDispatcherGenerator
 

P

Package - Class in org.apache.s4.tools
 
Package() - Constructor for class org.apache.s4.tools.Package
 
ParametersInjectionModule - Class in org.apache.s4.core.util
Injects String parameters from a map.
ParametersInjectionModule(Map<String, String>) - Constructor for class org.apache.s4.core.util.ParametersInjectionModule
 
parseArgs(Object, String[]) - Static method in class org.apache.s4.tools.Tools
 
PhysicalCluster - Class in org.apache.s4.comm.topology
The S4 physical cluster implementation.
PhysicalCluster(int) - Constructor for class org.apache.s4.comm.topology.PhysicalCluster
 
ProcessingElement - Class in org.apache.s4.core
Base class for implementing processing in S4.
ProcessingElement() - Constructor for class org.apache.s4.core.ProcessingElement
 
ProcessingElement(App) - Constructor for class org.apache.s4.core.ProcessingElement
Create a PE prototype.
put(String, Class<T>, T) - Method in class org.apache.s4.base.Event
Put an arbitrary key-value pair in the event.
put(Event) - Method in class org.apache.s4.core.RemoteStream
 
put(Event) - Method in class org.apache.s4.core.Stream
Sends an event.
put(Event) - Method in interface org.apache.s4.core.Streamable
Put an event into the streams.
putListField(String, List<String>) - Method in class org.apache.s4.comm.topology.ZNRecord
 
putMapField(String, Map<String, String>) - Method in class org.apache.s4.comm.topology.ZNRecord
 
putSimpleField(String, String) - Method in class org.apache.s4.comm.topology.ZNRecord
 

Q

queue - Variable in class org.apache.s4.core.Stream
 

R

readData(String, boolean) - Method in class org.apache.s4.comm.topology.ZkClient
 
receiveEvent(EventMessage) - Method in class org.apache.s4.core.Stream
The low level Receiver object call this method when a new Event is available.
Receiver - Class in org.apache.s4.core
The Receiver and its counterpart Sender are the top level classes of the communication layer.
Receiver(Listener, SerializerDeserializer) - Constructor for class org.apache.s4.core.Receiver
 
recover() - Method in class org.apache.s4.core.ProcessingElement
 
recv() - Method in interface org.apache.s4.base.Listener
Perform blocking receive on the appropriate communication channel
recv() - Method in class org.apache.s4.comm.tcp.TCPListener
 
recv() - Method in class org.apache.s4.comm.udp.UDPListener
 
register() - Method in class org.apache.s4.core.Stream
 
RemoteCluster - Interface in org.apache.s4.comm.topology
Represents a logical cluster external to the current cluster
RemoteEmitter - Interface in org.apache.s4.base
Marker interface for identifying emitters to remote S4 clusters.
RemoteEmitterFactory - Interface in org.apache.s4.comm
Used for creating RemoteEmitter instances depending on the cluster configuration.
RemoteEmitters - Class in org.apache.s4.comm.tcp
Manages the RemoteEmitter instances for sending messages to remote subclusters.
RemoteEmitters() - Constructor for class org.apache.s4.comm.tcp.RemoteEmitters
 
RemoteSender - Class in org.apache.s4.core
Sends events to a remote cluster.
RemoteSender(Emitter, Hasher) - Constructor for class org.apache.s4.core.RemoteSender
 
RemoteSenders - Class in org.apache.s4.core
Sends events to remote clusters.
RemoteSenders() - Constructor for class org.apache.s4.core.RemoteSenders
 
RemoteStream - Class in org.apache.s4.core
Stream that dispatches events to interested apps in remote clusters
RemoteStream(App, String, KeyFinder<Event>, RemoteSenders, Hasher, RemoteStreams, String) - Constructor for class org.apache.s4.core.RemoteStream
 
remoteStreamKeyFinder - Variable in class org.apache.s4.core.adapter.AdapterApp
 
RemoteStreams - Class in org.apache.s4.comm.topology
Monitors streams available in the S4 cluster.
RemoteStreams(String, int, int) - Constructor for class org.apache.s4.comm.topology.RemoteStreams
 
RemoteStreams.StreamType - Enum in org.apache.s4.comm.topology
 
removeAll() - Method in class org.apache.s4.core.ProcessingElement
 
removeChannel(int) - Method in class org.apache.s4.comm.tcp.TCPEmitter
 
removeListener(ClusterChangeListener) - Method in interface org.apache.s4.comm.topology.Cluster
 
removeListener(ClusterChangeListener) - Method in class org.apache.s4.comm.topology.ClusterFromZK
 
restoreState(ProcessingElement) - Method in class org.apache.s4.core.ProcessingElement
 
run() - Method in class org.apache.s4.comm.udp.UDPListener
 
run() - Method in class org.apache.s4.core.ft.CheckpointingTask
 
run() - Method in class org.apache.s4.core.ft.SaveStateTask
 
run() - Method in class org.apache.s4.core.Receiver
 
run() - Method in class org.apache.s4.core.Stream
 

S

S4ArgsBase - Class in org.apache.s4.tools
 
S4ArgsBase() - Constructor for class org.apache.s4.tools.S4ArgsBase
 
S4ArgsBase.GradleOptsConverter - Class in org.apache.s4.tools
 
S4ArgsBase.GradleOptsConverter() - Constructor for class org.apache.s4.tools.S4ArgsBase.GradleOptsConverter
 
S4R_URI - Static variable in class org.apache.s4.deploy.DistributedDeploymentManager
 
S4RFetcher - Interface in org.apache.s4.deploy
This interface defines methods to fetch S4R archive files from a URI.
S4RLoader - Class in org.apache.s4.base.util
A classloader that fetches and loads classes and resources from : Application classes in an S4R archive Application dependencies from an S4R archive Classes dynamically generated
S4RLoader(URL[]) - Constructor for class org.apache.s4.base.util.S4RLoader
 
S4RLoaderFactory - Class in org.apache.s4.base.util
Helper class for creating S4RLoader instances for a given S4R file.
S4RLoaderFactory() - Constructor for class org.apache.s4.base.util.S4RLoaderFactory
 
SafeKeeper - Class in org.apache.s4.core.ft
This class is responsible for coordinating interactions between the S4 event processor and the checkpoint storage backend.
SafeKeeper() - Constructor for class org.apache.s4.core.ft.SafeKeeper
 
saveState(ProcessingElement) - Method in interface org.apache.s4.core.ft.CheckpointingFramework
Serializes and stores state to the storage backend.
saveState(CheckpointId, byte[], StorageCallback) - Method in class org.apache.s4.core.ft.DefaultFileSystemStateStorage
 
saveState(ProcessingElement) - Method in class org.apache.s4.core.ft.NoOpCheckpointingFramework
 
saveState(ProcessingElement) - Method in class org.apache.s4.core.ft.SafeKeeper
 
saveState(CheckpointId, byte[], StorageCallback) - Method in interface org.apache.s4.core.ft.StateStorage
Stores a checkpoint.
SaveStateTask - Class in org.apache.s4.core.ft
Encapsulates a checkpoint request.
SaveStateTask(CheckpointId, byte[], StorageCallback, StateStorage) - Constructor for class org.apache.s4.core.ft.SaveStateTask
 
SaveStateTask(CheckpointId, Future<byte[]>, StorageCallback, StateStorage) - Constructor for class org.apache.s4.core.ft.SaveStateTask
 
send(int, EventMessage) - Method in interface org.apache.s4.base.Emitter
 
send(int, EventMessage) - Method in class org.apache.s4.comm.tcp.TCPEmitter
 
send(int, EventMessage) - Method in class org.apache.s4.comm.udp.UDPEmitter
 
send(String, EventMessage) - Method in class org.apache.s4.core.RemoteSender
 
send(String, Event) - Method in class org.apache.s4.core.RemoteSenders
 
Sender - Class in org.apache.s4.core
The Sender and its counterpart Receiver are the top level classes of the communication layer.
Sender(Emitter, SerializerDeserializer, Hasher, Assignment) - Constructor for class org.apache.s4.core.Sender
 
sendToRemotePartitions(Event) - Method in class org.apache.s4.core.Sender
Send an event to all the remote partitions in the cluster.
serialize(Object) - Method in interface org.apache.s4.base.SerializerDeserializer
 
serialize(Object) - Method in class org.apache.s4.comm.serialize.KryoSerDeser
 
serialize(Object) - Method in class org.apache.s4.comm.topology.ZNRecordSerializer
 
SerializerDeserializer - Interface in org.apache.s4.base
Defines serialization and deserialization methods used within the S4 platform, typically for events and PEs.
serializeState() - Method in class org.apache.s4.core.ProcessingElement
 
SerializeTask - Class in org.apache.s4.core.ft
Encaspulate a PE serialization operation.
SerializeTask(ProcessingElement) - Constructor for class org.apache.s4.core.ft.SerializeTask
 
Server - Class in org.apache.s4.core
The Server instance coordinates activities in a cluster node including loading and unloading of applications and instantiating the communication layer.
Server(String, String, String, String, int, int) - Constructor for class org.apache.s4.core.Server
 
setApp(App) - Method in class org.apache.s4.core.ProcessingElement
 
setAppId(int) - Method in class org.apache.s4.base.Event
All events must be assigned the unique App ID of the App that owns the stream to which this event is injected.
setCheckpointingConfig(CheckpointingConfig) - Method in class org.apache.s4.core.ProcessingElement
 
setClockType(App.ClockType) - Method in class org.apache.s4.core.App
Set the App.ClockType.
setId(int) - Method in class org.apache.s4.core.App
 
setInitialBufferSize(int) - Method in class org.apache.s4.comm.serialize.KryoSerDeser
 
setKey(KeyFinder<T>) - Method in class org.apache.s4.core.Stream
Define the key finder for this stream.
setKey(String) - Method in class org.apache.s4.core.Stream
Define the key finder for this stream using a descriptor.
setKeyFinder(KeyFinder<Event>) - Method in class org.apache.s4.core.adapter.AdapterApp
This method allows to specify a keyfinder in order to partition the output stream
setMaxBufferSize(int) - Method in class org.apache.s4.comm.serialize.KryoSerDeser
 
setName(String) - Method in class org.apache.s4.comm.topology.PhysicalCluster
 
setName(String) - Method in class org.apache.s4.core.ProcessingElement
 
setName(String) - Method in class org.apache.s4.core.Stream
Name the stream.
setPE(ProcessingElement) - Method in class org.apache.s4.core.Stream
Send events from this stream to a PE.
setPECache(int, long, TimeUnit) - Method in class org.apache.s4.core.ProcessingElement
Set PE expiration and cache size.
setPECache(int) - Method in class org.apache.s4.core.ProcessingElement
Sets the max size of the PE cache.
setPEs(ProcessingElement[]) - Method in class org.apache.s4.core.Stream
Send events from this stream to various PEs.
setSingleton(boolean) - Method in class org.apache.s4.core.ProcessingElement
Makes this PE a singleton.
setStreamId(String) - Method in class org.apache.s4.base.Event
 
setTimerInterval(long, TimeUnit) - Method in class org.apache.s4.core.ProcessingElement
Set a timer that calls ProcessingElement.onTime().
setTrigger(Class<? extends Event>, int, long, TimeUnit) - Method in class org.apache.s4.core.ProcessingElement
This trigger is fired when the following conditions occur: An event of eventType arrived to the PE instance numEvents have arrived since the last time this trigger was fired -OR- time since last event is greater than interval.
setup(String, int, int) - Method in class org.apache.s4.comm.tools.TaskSetup
 
Slot<T> - Interface in org.apache.s4.core.window
A convenience window slot, that aggregates elements of type .
SlotFactory<T> - Interface in org.apache.s4.core.window
Defines factory for window slots
start() - Method in class org.apache.s4.core.App
This method is called by the container after initialization.
start() - Method in class org.apache.s4.core.RemoteStream
 
start(Injector) - Method in class org.apache.s4.core.Server
 
start() - Method in class org.apache.s4.core.Stream
 
start() - Method in interface org.apache.s4.core.Streamable
Starting the stream starts the associated dequeuing thread.
start() - Method in interface org.apache.s4.deploy.DeploymentManager
 
start() - Method in class org.apache.s4.deploy.DistributedDeploymentManager
 
start() - Method in class org.apache.s4.deploy.NoOpDeploymentManager
 
startApp(App, String, String) - Method in class org.apache.s4.core.Server
 
StateStorage - Interface in org.apache.s4.core.ft
Defines the methods that must be implemented by a backend storage for checkpoints.
Status - Class in org.apache.s4.tools
 
Status() - Constructor for class org.apache.s4.tools.Status
 
stop() - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
Stops the the sliding window.
StorageCallback - Interface in org.apache.s4.core.ft
Callback for reporting the result of an asynchronous storage operation
StorageCallbackFactory - Interface in org.apache.s4.core.ft
A factory for creating storage callbacks.
storageOperationResult(CheckpointingFramework.StorageResultCode, Object) - Method in interface org.apache.s4.core.ft.StorageCallback
Notifies the result of a storage operation
Stream<T extends Event> - Class in org.apache.s4.core
Stream and ProcessingElement objects represent the links and nodes in the application graph.
Stream(App) - Constructor for class org.apache.s4.core.Stream
Send events using a KeyFinder.
Streamable<T extends Event> - Interface in org.apache.s4.core
We use this interface to put events into objects.
StreamConsumer - Class in org.apache.s4.comm.topology
A subscriber to a published stream.
StreamConsumer(int, String) - Constructor for class org.apache.s4.comm.topology.StreamConsumer
 

T

TaskSetup - Class in org.apache.s4.comm.tools
Used for defining and dimensioning logical clusters in Zookeeper.
TaskSetup(String) - Constructor for class org.apache.s4.comm.tools.TaskSetup
 
TCPEmitter - Class in org.apache.s4.comm.tcp
TCPEmitter - Uses TCP to send messages across partitions.
TCPEmitter(Cluster, int) - Constructor for class org.apache.s4.comm.tcp.TCPEmitter
 
TCPListener - Class in org.apache.s4.comm.tcp
Receives messages through TCP for the assigned subcluster.
TCPListener(Assignment, int) - Constructor for class org.apache.s4.comm.tcp.TCPListener
 
TCPListener.ChannelHandler - Class in org.apache.s4.comm.tcp
 
TCPListener.ChannelHandler(BlockingQueue<byte[]>) - Constructor for class org.apache.s4.comm.tcp.TCPListener.ChannelHandler
 
TCPRemoteEmitter - Class in org.apache.s4.comm.tcp
Emitter to remote subclusters.
TCPRemoteEmitter(Cluster, int) - Constructor for class org.apache.s4.comm.tcp.TCPRemoteEmitter
Sends to remote subclusters.
timeUnit(TimeUnit) - Method in class org.apache.s4.core.ft.CheckpointingConfig.Builder
 
timeUnit - Variable in class org.apache.s4.core.ft.CheckpointingConfig
 
Tools - Class in org.apache.s4.tools
 
Tools() - Constructor for class org.apache.s4.tools.Tools
 
toString() - Method in class org.apache.s4.base.Event
 
toString() - Method in class org.apache.s4.comm.topology.ClusterNode
 
toString() - Method in class org.apache.s4.comm.topology.PhysicalCluster
 
toString() - Method in class org.apache.s4.core.ft.CheckpointId
 
toString() - Method in class org.apache.s4.core.ProcessingElement
 

U

UDPEmitter - Class in org.apache.s4.comm.udp
UDP based emitter.
UDPEmitter(Cluster) - Constructor for class org.apache.s4.comm.udp.UDPEmitter
 
UDPListener - Class in org.apache.s4.comm.udp
Implementation of a simple UDP listener.
UDPListener(Assignment) - Constructor for class org.apache.s4.comm.udp.UDPListener
 
UDPListener(Assignment, int) - Constructor for class org.apache.s4.comm.udp.UDPListener
 
UDPRemoteEmitter - Class in org.apache.s4.comm.udp
UDP-based emitter for sending events to remote clusters.
UDPRemoteEmitter(Cluster) - Constructor for class org.apache.s4.comm.udp.UDPRemoteEmitter
Sends to remote subclusters.
update(T) - Method in class org.apache.s4.core.window.DefaultAggregatingSlot
 
update(Double) - Method in class org.apache.s4.core.window.OHCLSlot
 
update(T) - Method in interface org.apache.s4.core.window.Slot
Add a single data element
updateOpenSlot(U) - Method in class org.apache.s4.core.window.AbstractSlidingWindowPE
 

V

validate(String, String) - Method in class org.apache.s4.tools.FileExistsValidator
 
valueOf(String) - Static method in enum org.apache.s4.comm.topology.RemoteStreams.StreamType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.s4.core.App.ClockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.s4.core.ft.CheckpointingConfig.CheckpointingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.s4.core.ft.CheckpointingFramework.StorageResultCode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.s4.comm.topology.RemoteStreams.StreamType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.s4.core.App.ClockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.s4.core.ft.CheckpointingConfig.CheckpointingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.s4.core.ft.CheckpointingFramework.StorageResultCode
Returns an array containing the constants of this enum type, in the order they are declared.

Z

ZkClient - Class in org.apache.s4.comm.topology
Overwriting the ZKclient since the org.I0Itec.zkclient.ZkClient does not expose some important methods
ZkClient(IZkConnection, int, ZkSerializer) - Constructor for class org.apache.s4.comm.topology.ZkClient
 
ZkClient(IZkConnection, int) - Constructor for class org.apache.s4.comm.topology.ZkClient
 
ZkClient(IZkConnection) - Constructor for class org.apache.s4.comm.topology.ZkClient
 
ZkClient(String, int, int) - Constructor for class org.apache.s4.comm.topology.ZkClient
 
ZkClient(String, int) - Constructor for class org.apache.s4.comm.topology.ZkClient
 
ZkClient(String) - Constructor for class org.apache.s4.comm.topology.ZkClient
 
ZKServer - Class in org.apache.s4.tools
 
ZKServer() - Constructor for class org.apache.s4.tools.ZKServer
 
ZKServer.ClusterConfig - Class in org.apache.s4.tools
 
ZKServer.ClusterConfig(String) - Constructor for class org.apache.s4.tools.ZKServer.ClusterConfig
 
ZKServer.ClusterConfigsConverter - Class in org.apache.s4.tools
 
ZKServer.ClusterConfigsConverter() - Constructor for class org.apache.s4.tools.ZKServer.ClusterConfigsConverter
 
ZNRecord - Class in org.apache.s4.comm.topology
ZooKeeper's custom znode data structure.
ZNRecord(String) - Constructor for class org.apache.s4.comm.topology.ZNRecord
 
ZNRecord(ZNRecord) - Constructor for class org.apache.s4.comm.topology.ZNRecord
 
ZNRecordSerializer - Class in org.apache.s4.comm.topology
Utility to serialize/deserialize data in ZK.
ZNRecordSerializer() - Constructor for class org.apache.s4.comm.topology.ZNRecordSerializer
 

A B C D E F G H I K L M N O P Q R S T U V Z