A C D E G H I M N O P R S T U V 
All Classes All Packages

A

accumulator() - Method in class io.numaproj.numaflow.sessionreducer.model.SessionReducer
accumulator transforms the current state of the session into a byte array representation.
ack(AckRequest) - Method in class io.numaproj.numaflow.sourcer.Sourcer
method will be used for acknowledging messages from source.
AckRequest - Interface in io.numaproj.numaflow.sourcer
AckRequest request for acknowledging messages.
ActorRequestType - Enum in io.numaproj.numaflow.sessionreducer
ActorRequestType represents the purpose of an ActorRequest.
addAllMessages(Iterable<Message>) - Method in class io.numaproj.numaflow.sourcetransformer.MessageList.MessageListBuilder
 
addDatum(Datum) - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.TestBlockingIterator
 
addDatum(Datum) - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.TestListIterator
 
addMessage(String[], Datum, Metadata) - Method in class io.numaproj.numaflow.reducer.Reducer
addMessage will be invoked for each input message.
addMessages(Iterable<Message>) - Method in class io.numaproj.numaflow.mapper.MessageList.MessageListBuilder
 
addMessages(Iterable<Message>) - Method in class io.numaproj.numaflow.reducer.MessageList.MessageListBuilder
 
addResponses(Iterable<Response>) - Method in class io.numaproj.numaflow.sinker.ResponseList.ResponseListBuilder
 
APPEND - io.numaproj.numaflow.sessionreducer.ActorRequestType
 
awaitTermination() - Method in class io.numaproj.numaflow.mapper.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.mapstreamer.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.reducer.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.reducestreamer.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.sessionreducer.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.sideinput.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.sinker.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.sourcer.Server
Blocks until the server has terminated.
awaitTermination() - Method in class io.numaproj.numaflow.sourcetransformer.Server
Blocks until the server has terminated.

C

Client() - Constructor for class io.numaproj.numaflow.mapper.MapperTestKit.Client
empty constructor for Client.
Client() - Constructor for class io.numaproj.numaflow.reducer.ReducerTestKit.Client
Create a new Client with the default host and port.
Client() - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit.Client
Create a new Client with default host and port.
Client() - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
empty constructor for Client.
Client() - Constructor for class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit.Client
empty constructor for Client.
Client(String, int) - Constructor for class io.numaproj.numaflow.mapper.MapperTestKit.Client
constructor for Client with host and port.
Client(String, int) - Constructor for class io.numaproj.numaflow.reducer.ReducerTestKit.Client
Create a new Client with the given host and port.
Client(String, int) - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit.Client
Create a new Client with the given host and port.
Client(String, int) - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
Create a new SourcerClient with the given host and port.
Client(String, int) - Constructor for class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit.Client
constructor for Client with host and port.
close() - Method in class io.numaproj.numaflow.mapper.MapperTestKit.Client
Close the client.
close() - Method in class io.numaproj.numaflow.reducer.ReducerTestKit.Client
close the client.
close() - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.Client
close the client.
close() - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.TestBlockingIterator
 
close() - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
close closes the client.
close() - Method in class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit.Client
Close the client.
CLOSE - io.numaproj.numaflow.sessionreducer.ActorRequestType
 
Constants - Class in io.numaproj.numaflow.sideinput
 
Constants() - Constructor for class io.numaproj.numaflow.sideinput.Constants
 
createBroadcastMessage(byte[]) - Static method in class io.numaproj.numaflow.sideinput.Message
createBroadcastMessage creates a new Message with the given value This is used to broadcast the message to other side input vertices.
createNoBroadcastMessage() - Static method in class io.numaproj.numaflow.sideinput.Message
createNoBroadcastMessage creates a new Message with noBroadcast flag set to true This is used to drop the message and not to broadcast it to other side input vertices.
createReducer() - Method in class io.numaproj.numaflow.reducer.ReducerFactory
 
createReduceStreamer() - Method in class io.numaproj.numaflow.reducestreamer.model.ReduceStreamerFactory
Helper function to create a reduce streamer.
createSessionReducer() - Method in class io.numaproj.numaflow.sessionreducer.model.SessionReducerFactory
Helper function to create a session reducer.

D

Datum - Interface in io.numaproj.numaflow.mapper
Datum contains methods to get the payload information.
Datum - Interface in io.numaproj.numaflow.mapstreamer
Datum contains methods to get the payload information.
Datum - Interface in io.numaproj.numaflow.reducer
Datum contains methods to get the payload information.
Datum - Interface in io.numaproj.numaflow.reducestreamer.model
Datum contains methods to get the payload information.
Datum - Interface in io.numaproj.numaflow.sessionreducer.model
Datum contains methods to get the payload information.
Datum - Interface in io.numaproj.numaflow.sinker
Datum contains methods to get the payload information.
Datum - Interface in io.numaproj.numaflow.sourcetransformer
Datum contains methods to get the payload information.
DatumIterator - Interface in io.numaproj.numaflow.sinker
An iterator over a collection of Datum elements.
defaultPartitions() - Static method in class io.numaproj.numaflow.sourcer.Sourcer
method returns default partitions for the source.
DROP - Static variable in class io.numaproj.numaflow.mapper.Message
 
DROP - Static variable in class io.numaproj.numaflow.mapstreamer.Message
 
DROP - Static variable in class io.numaproj.numaflow.reducer.Message
 
DROP - Static variable in class io.numaproj.numaflow.reducestreamer.model.Message
 
DROP - Static variable in class io.numaproj.numaflow.sessionreducer.model.Message
 
DROP - Static variable in class io.numaproj.numaflow.sourcetransformer.Message
 

E

EXPAND - io.numaproj.numaflow.sessionreducer.ActorRequestType
 

G

GET_ACCUMULATOR - io.numaproj.numaflow.sessionreducer.ActorRequestType
 
getCount() - Method in interface io.numaproj.numaflow.sourcer.ReadRequest
 
getEndTime() - Method in interface io.numaproj.numaflow.reducer.IntervalWindow
method to get the end time of the interval window
getEndTime() - Method in class io.numaproj.numaflow.reducer.metadata.IntervalWindowImpl
 
getEndTime() - Method in interface io.numaproj.numaflow.reducestreamer.model.IntervalWindow
method to get the end time of the interval window
getEventTime() - Method in interface io.numaproj.numaflow.mapper.Datum
method to get the event time of the payload
getEventTime() - Method in interface io.numaproj.numaflow.mapstreamer.Datum
method to get the event time of the payload
getEventTime() - Method in interface io.numaproj.numaflow.reducer.Datum
method to get the event time of the payload
getEventTime() - Method in interface io.numaproj.numaflow.reducestreamer.model.Datum
method to get the event time of the payload
getEventTime() - Method in interface io.numaproj.numaflow.sessionreducer.model.Datum
method to get the event time of the payload
getEventTime() - Method in interface io.numaproj.numaflow.sinker.Datum
method to get the event time of the payload
getEventTime() - Method in interface io.numaproj.numaflow.sourcetransformer.Datum
method to get the event time of the payload
getHeaders() - Method in interface io.numaproj.numaflow.mapper.Datum
method to get the headers information of the payload
getHeaders() - Method in interface io.numaproj.numaflow.mapstreamer.Datum
method to get the headers information of the payload
getHeaders() - Method in interface io.numaproj.numaflow.reducer.Datum
method to get the headers information of the payload
getHeaders() - Method in interface io.numaproj.numaflow.reducestreamer.model.Datum
method to get the headers information of the payload
getHeaders() - Method in interface io.numaproj.numaflow.sessionreducer.model.Datum
method to get the headers information of the payload
getHeaders() - Method in interface io.numaproj.numaflow.sinker.Datum
method to get the headers information of the payload
getHeaders() - Method in interface io.numaproj.numaflow.sourcetransformer.Datum
method to get the headers information of the payload
getId() - Method in interface io.numaproj.numaflow.sinker.Datum
method to get the ID for the Payload
getIntervalWindow() - Method in interface io.numaproj.numaflow.reducer.Metadata
method to get the interval window.
getIntervalWindow() - Method in class io.numaproj.numaflow.reducer.metadata.MetadataImpl
 
getIntervalWindow() - Method in interface io.numaproj.numaflow.reducestreamer.model.Metadata
method to get the interval window.
getKeys() - Method in interface io.numaproj.numaflow.sinker.Datum
method to get the payload keys
getOffsets() - Method in interface io.numaproj.numaflow.sourcer.AckRequest
 
getOutput(String[], Metadata) - Method in class io.numaproj.numaflow.reducer.Reducer
getOutput will be invoked at the end of input.
getPartitions() - Method in class io.numaproj.numaflow.sourcer.Sourcer
method returns the partitions associated with the source, will be used by the platform to determine the partitions to which the watermark should be published.
getPending() - Method in class io.numaproj.numaflow.sourcer.Sourcer
method will be used for getting the number of pending messages from source.
getStartTime() - Method in interface io.numaproj.numaflow.reducer.IntervalWindow
method to get the start time of the interval window
getStartTime() - Method in class io.numaproj.numaflow.reducer.metadata.IntervalWindowImpl
 
getStartTime() - Method in interface io.numaproj.numaflow.reducestreamer.model.IntervalWindow
method to get the start time of the interval window
getTimeout() - Method in interface io.numaproj.numaflow.sourcer.ReadRequest
 
getUniqueIdentifier(Sessionreduce.KeyedWindow) - Static method in class io.numaproj.numaflow.sessionreducer.UniqueIdGenerator
 
getValue() - Method in interface io.numaproj.numaflow.mapper.Datum
method to get the payload value
getValue() - Method in interface io.numaproj.numaflow.mapstreamer.Datum
method to get the payload value
getValue() - Method in interface io.numaproj.numaflow.reducer.Datum
method to get the payload value
getValue() - Method in interface io.numaproj.numaflow.reducestreamer.model.Datum
method to get the payload value
getValue() - Method in interface io.numaproj.numaflow.sessionreducer.model.Datum
method to get the payload value
getValue() - Method in interface io.numaproj.numaflow.sinker.Datum
method to get the payload value
getValue() - Method in interface io.numaproj.numaflow.sourcetransformer.Datum
method to get the payload value
getWatermark() - Method in interface io.numaproj.numaflow.mapper.Datum
method to get the watermark information
getWatermark() - Method in interface io.numaproj.numaflow.mapstreamer.Datum
method to get the watermark information
getWatermark() - Method in interface io.numaproj.numaflow.reducer.Datum
method to get the watermark information
getWatermark() - Method in interface io.numaproj.numaflow.reducestreamer.model.Datum
method to get the watermark information
getWatermark() - Method in interface io.numaproj.numaflow.sessionreducer.model.Datum
method to get the watermark information
getWatermark() - Method in interface io.numaproj.numaflow.sinker.Datum
method to get the watermark information
getWatermark() - Method in interface io.numaproj.numaflow.sourcetransformer.Datum
method to get the watermark information
GRPCConfig - Class in io.numaproj.numaflow.mapper
GRPCConfig is used to provide configurations for map gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.mapstreamer
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.reducer
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.reducestreamer
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.sessionreducer
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.sideinput
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.sinker
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.sourcer
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig - Class in io.numaproj.numaflow.sourcetransformer
GRPCConfig is used to provide configurations for gRPC server.
GRPCConfig() - Constructor for class io.numaproj.numaflow.mapper.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.mapstreamer.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.reducer.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.reducestreamer.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.sessionreducer.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.sideinput.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.sinker.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.sourcer.GRPCConfig
 
GRPCConfig() - Constructor for class io.numaproj.numaflow.sourcetransformer.GRPCConfig
 

H

handleEndOfStream(String[], OutputStreamObserver, Metadata) - Method in class io.numaproj.numaflow.reducestreamer.model.ReduceStreamer
handleEndOfStream handles the closure of the reduce input stream.
handleEndOfStream(String[], OutputStreamObserver) - Method in class io.numaproj.numaflow.sessionreducer.model.SessionReducer
handleEndOfStream handles the closure of the session reduce input stream.

I

IntervalWindow - Interface in io.numaproj.numaflow.reducer
IntervalWindow contains methods to get the information for a given interval window.
IntervalWindow - Interface in io.numaproj.numaflow.reducestreamer.model
IntervalWindow contains methods to get the information for a given interval window.
IntervalWindowImpl - Class in io.numaproj.numaflow.reducer.metadata
IntervalWindowImpl implements IntervalWindow interface which will be passed as metadata to reduce handlers
IntervalWindowImpl() - Constructor for class io.numaproj.numaflow.reducer.metadata.IntervalWindowImpl
 
io.numaproj.numaflow.mapper - package io.numaproj.numaflow.mapper
 
io.numaproj.numaflow.mapstreamer - package io.numaproj.numaflow.mapstreamer
 
io.numaproj.numaflow.reducer - package io.numaproj.numaflow.reducer
 
io.numaproj.numaflow.reducer.metadata - package io.numaproj.numaflow.reducer.metadata
 
io.numaproj.numaflow.reducestreamer - package io.numaproj.numaflow.reducestreamer
 
io.numaproj.numaflow.reducestreamer.model - package io.numaproj.numaflow.reducestreamer.model
 
io.numaproj.numaflow.sessionreducer - package io.numaproj.numaflow.sessionreducer
 
io.numaproj.numaflow.sessionreducer.model - package io.numaproj.numaflow.sessionreducer.model
 
io.numaproj.numaflow.sideinput - package io.numaproj.numaflow.sideinput
 
io.numaproj.numaflow.sinker - package io.numaproj.numaflow.sinker
 
io.numaproj.numaflow.sourcer - package io.numaproj.numaflow.sourcer
 
io.numaproj.numaflow.sourcetransformer - package io.numaproj.numaflow.sourcetransformer
 

M

Mapper - Class in io.numaproj.numaflow.mapper
Mapper exposes method for performing map operation.
Mapper() - Constructor for class io.numaproj.numaflow.mapper.Mapper
 
MapperTestKit - Class in io.numaproj.numaflow.mapper
MapperTestKit is a test kit for testing Mapper implementations.
MapperTestKit(Mapper) - Constructor for class io.numaproj.numaflow.mapper.MapperTestKit
Create a new MapperTestKit with the given Mapper.
MapperTestKit(Mapper, GRPCConfig) - Constructor for class io.numaproj.numaflow.mapper.MapperTestKit
Create a new MapperTestKit with the given Mapper and GRPCConfig.
MapperTestKit.Client - Class in io.numaproj.numaflow.mapper
Client is a client for sending requests to the map server.
MapperTestKit.TestDatum - Class in io.numaproj.numaflow.mapper
TestDatum is a Datum for testing.
MapStreamer - Class in io.numaproj.numaflow.mapstreamer
MapStreamer exposes method for performing map streaming operation.
MapStreamer() - Constructor for class io.numaproj.numaflow.mapstreamer.MapStreamer
 
mergeAccumulator(byte[]) - Method in class io.numaproj.numaflow.sessionreducer.model.SessionReducer
mergeAccumulator merges the current session with another session.
MergeDoneResponse - Class in io.numaproj.numaflow.sessionreducer
MergeDoneResponse indicates the current MERGE request is done.
MergeDoneResponse() - Constructor for class io.numaproj.numaflow.sessionreducer.MergeDoneResponse
 
Message - Class in io.numaproj.numaflow.mapper
Message is used to wrap the data returned by Mapper.
Message - Class in io.numaproj.numaflow.mapstreamer
Message is used to wrap the data returned by MapStreamer.
Message - Class in io.numaproj.numaflow.reducer
Message is used to wrap the data returned by Reducer functions.
Message - Class in io.numaproj.numaflow.reducestreamer.model
Message is used to wrap the data returned by Reduce Streamer functions.
Message - Class in io.numaproj.numaflow.sessionreducer.model
Message is used to wrap the data returned by Session Reducer functions.
Message - Class in io.numaproj.numaflow.sideinput
Message is used to wrap the data returned by Side Input Retriever.
Message - Class in io.numaproj.numaflow.sourcer
Message is used to wrap the data returned by Sourcer.
Message - Class in io.numaproj.numaflow.sourcetransformer
Message is used to wrap the data return by SourceTransformer functions.
Message() - Constructor for class io.numaproj.numaflow.sideinput.Message
 
Message(byte[]) - Constructor for class io.numaproj.numaflow.mapper.Message
used to create Message with value.
Message(byte[]) - Constructor for class io.numaproj.numaflow.mapstreamer.Message
used to create Message with value.
Message(byte[]) - Constructor for class io.numaproj.numaflow.reducer.Message
used to create Message with value.
Message(byte[]) - Constructor for class io.numaproj.numaflow.reducestreamer.model.Message
used to create Message with value.
Message(byte[]) - Constructor for class io.numaproj.numaflow.sessionreducer.model.Message
used to create Message with value.
Message(byte[], Offset, Instant) - Constructor for class io.numaproj.numaflow.sourcer.Message
used to create Message with value, offset and eventTime.
Message(byte[], Offset, Instant, String[]) - Constructor for class io.numaproj.numaflow.sourcer.Message
used to create Message with value, offset, eventTime and keys.
Message(byte[], Offset, Instant, String[], Map<String, String>) - Constructor for class io.numaproj.numaflow.sourcer.Message
used to create Message with value, offset, eventTime, keys and headers.
Message(byte[], Offset, Instant, Map<String, String>) - Constructor for class io.numaproj.numaflow.sourcer.Message
used to create Message with value, offset, eventTime and headers.
Message(byte[], String[]) - Constructor for class io.numaproj.numaflow.mapper.Message
used to create Message with value and keys.
Message(byte[], String[]) - Constructor for class io.numaproj.numaflow.mapstreamer.Message
used to create Message with value and keys.
Message(byte[], String[]) - Constructor for class io.numaproj.numaflow.reducer.Message
used to create Message with value and keys.
Message(byte[], String[]) - Constructor for class io.numaproj.numaflow.reducestreamer.model.Message
used to create Message with value and keys.
Message(byte[], String[]) - Constructor for class io.numaproj.numaflow.sessionreducer.model.Message
used to create Message with value and keys.
Message(byte[], String[], String[]) - Constructor for class io.numaproj.numaflow.mapper.Message
used to create Message with value, keys and tags(used for conditional forwarding)
Message(byte[], String[], String[]) - Constructor for class io.numaproj.numaflow.mapstreamer.Message
used to create Message with value, keys and tags(used for conditional forwarding)
Message(byte[], String[], String[]) - Constructor for class io.numaproj.numaflow.reducer.Message
used to create Message with value, keys and tags(used for conditional forwarding)
Message(byte[], String[], String[]) - Constructor for class io.numaproj.numaflow.reducestreamer.model.Message
used to create Message with value, keys and tags(used for conditional forwarding)
Message(byte[], String[], String[]) - Constructor for class io.numaproj.numaflow.sessionreducer.model.Message
used to create Message with value, keys and tags(used for conditional forwarding)
Message(byte[], Instant) - Constructor for class io.numaproj.numaflow.sourcetransformer.Message
used to create Message with value and eventTime.
Message(byte[], Instant, String[]) - Constructor for class io.numaproj.numaflow.sourcetransformer.Message
used to create Message with value, eventTime and keys
Message(byte[], Instant, String[], String[]) - Constructor for class io.numaproj.numaflow.sourcetransformer.Message
used to create Message with value, eventTime, keys and tags(used for conditional forwarding)
MessageList - Class in io.numaproj.numaflow.mapper
MessageList is used to return the list of Messages returned from Map functions.
MessageList - Class in io.numaproj.numaflow.reducer
 
MessageList - Class in io.numaproj.numaflow.sourcetransformer
MessageList is used to return the list of Messages from SourceTransformer functions.
MessageList() - Constructor for class io.numaproj.numaflow.mapper.MessageList
 
MessageList() - Constructor for class io.numaproj.numaflow.reducer.MessageList
 
MessageList() - Constructor for class io.numaproj.numaflow.sourcetransformer.MessageList
 
MessageList.MessageListBuilder - Class in io.numaproj.numaflow.mapper
Builder to build MessageList
MessageList.MessageListBuilder - Class in io.numaproj.numaflow.reducer
Builder to build MessageList
MessageList.MessageListBuilder - Class in io.numaproj.numaflow.sourcetransformer
Builder to build MessageList
MessageListBuilder() - Constructor for class io.numaproj.numaflow.mapper.MessageList.MessageListBuilder
 
MessageListBuilder() - Constructor for class io.numaproj.numaflow.reducer.MessageList.MessageListBuilder
 
MessageListBuilder() - Constructor for class io.numaproj.numaflow.sourcetransformer.MessageList.MessageListBuilder
 
Metadata - Interface in io.numaproj.numaflow.reducer
Metadata contains methods to get the metadata for the reduce operation.
Metadata - Interface in io.numaproj.numaflow.reducestreamer.model
Metadata contains methods to get the metadata for the reduce stream operation.
MetadataImpl - Class in io.numaproj.numaflow.reducer.metadata
MetadataImpl implements Metadata interface which will be passed to reduce handlers
MetadataImpl() - Constructor for class io.numaproj.numaflow.reducer.metadata.MetadataImpl
 

N

next() - Method in interface io.numaproj.numaflow.sinker.DatumIterator
Returns the next element in the iterator This method blocks until an element becomes available in the blocking queue.
next() - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.TestBlockingIterator
 
next() - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.TestListIterator
 

O

Offset - Class in io.numaproj.numaflow.sourcer
Offset is the message offset.
Offset(byte[]) - Constructor for class io.numaproj.numaflow.sourcer.Offset
used to create Offset with value and default partitionId.
Offset(byte[], Integer) - Constructor for class io.numaproj.numaflow.sourcer.Offset
used to create Offset with value and partitionId.
OPEN - io.numaproj.numaflow.sessionreducer.ActorRequestType
 
OutputObserver - Interface in io.numaproj.numaflow.mapstreamer
OutputObserver receives messages from the MapStreamer.
OutputObserver - Interface in io.numaproj.numaflow.sourcer
OutputObserver receives messages from the sourcer.
OutputStreamObserver - Interface in io.numaproj.numaflow.reducestreamer.model
OutputStreamObserver sends to the output stream, the messages generate by the reduce streamer.
OutputStreamObserver - Interface in io.numaproj.numaflow.sessionreducer.model
OutputStreamObserver sends to the output stream, the messages generate by the session reducer.

P

processMessage(String[], Datum) - Method in class io.numaproj.numaflow.mapper.Mapper
method which will be used for processing messages.
processMessage(String[], Datum, OutputObserver) - Method in class io.numaproj.numaflow.mapstreamer.MapStreamer
method which will be used for processing streaming messages.
processMessage(String[], Datum, OutputStreamObserver, Metadata) - Method in class io.numaproj.numaflow.reducestreamer.model.ReduceStreamer
processMessage is invoked for each reduce input message.
processMessage(String[], Datum, OutputStreamObserver) - Method in class io.numaproj.numaflow.sessionreducer.model.SessionReducer
processMessage is invoked for each session reduce input message.
processMessage(String[], Datum) - Method in class io.numaproj.numaflow.sourcetransformer.SourceTransformer
method which will be used for processing messages.
processMessages(DatumIterator) - Method in class io.numaproj.numaflow.sinker.Sinker
method will be used for processing messages.

R

read(ReadRequest, OutputObserver) - Method in class io.numaproj.numaflow.sourcer.Sourcer
method will be used for reading messages from source.
ReadRequest - Interface in io.numaproj.numaflow.sourcer
ReadRequest request for reading messages from source.
Reducer - Class in io.numaproj.numaflow.reducer
Reducer exposes methods for performing reduce operation.
Reducer() - Constructor for class io.numaproj.numaflow.reducer.Reducer
 
ReducerFactory<ReducerT extends Reducer> - Class in io.numaproj.numaflow.reducer
ReducerFactory is the factory for Reducer.
ReducerFactory() - Constructor for class io.numaproj.numaflow.reducer.ReducerFactory
 
ReducerTestKit - Class in io.numaproj.numaflow.reducer
ReducerTestKit is a test kit for testing Reducer implementations.
ReducerTestKit(ReducerFactory<? extends Reducer>) - Constructor for class io.numaproj.numaflow.reducer.ReducerTestKit
 
ReducerTestKit(ReducerFactory<? extends Reducer>, GRPCConfig) - Constructor for class io.numaproj.numaflow.reducer.ReducerTestKit
 
ReducerTestKit.Client - Class in io.numaproj.numaflow.reducer
Client is a client to send requests to the server.
ReducerTestKit.TestDatum - Class in io.numaproj.numaflow.reducer
TestDatum is a simple implementation of Datum for testing.
ReducerTestKit.TestReduceRequest - Class in io.numaproj.numaflow.reducer
TestReduceRequest is the request to send to the server for testing.
ReduceStreamer - Class in io.numaproj.numaflow.reducestreamer.model
ReduceStreamer exposes methods for performing reduce streaming operations.
ReduceStreamer() - Constructor for class io.numaproj.numaflow.reducestreamer.model.ReduceStreamer
 
ReduceStreamerFactory<ReduceStreamerT extends ReduceStreamer> - Class in io.numaproj.numaflow.reducestreamer.model
ReduceStreamerFactory is the factory for ReduceStreamer.
ReduceStreamerFactory() - Constructor for class io.numaproj.numaflow.reducestreamer.model.ReduceStreamerFactory
 
Response - Class in io.numaproj.numaflow.sinker
Response is used to send response from the user defined sinker.
Response() - Constructor for class io.numaproj.numaflow.sinker.Response
 
responseFailure(String, String) - Static method in class io.numaproj.numaflow.sinker.Response
Static method to create response for failed message processing.
responseFallback(String) - Static method in class io.numaproj.numaflow.sinker.Response
Static method to create response for fallback message.
ResponseList - Class in io.numaproj.numaflow.sinker
ResponseList is used to return the list of responses from user defined sinker.
ResponseList() - Constructor for class io.numaproj.numaflow.sinker.ResponseList
 
ResponseList.ResponseListBuilder - Class in io.numaproj.numaflow.sinker
Builder to build ResponseList
ResponseListBuilder() - Constructor for class io.numaproj.numaflow.sinker.ResponseList.ResponseListBuilder
 
responseOK(String) - Static method in class io.numaproj.numaflow.sinker.Response
Static method to create response for successful message processing.
retrieveSideInput() - Method in class io.numaproj.numaflow.sideinput.SideInputRetriever
method which will be used for retrieving side input.

S

send(Message) - Method in interface io.numaproj.numaflow.mapstreamer.OutputObserver
method will be used for sending messages to the output.
send(Message) - Method in interface io.numaproj.numaflow.reducestreamer.model.OutputStreamObserver
method will be used for sending messages to the output stream.
send(Message) - Method in interface io.numaproj.numaflow.sessionreducer.model.OutputStreamObserver
method will be used for sending messages to the output stream.
send(Message) - Method in interface io.numaproj.numaflow.sourcer.OutputObserver
method will be used for sending messages to the output.
send(Message) - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit.TestListBasedObserver
 
sendAckRequest(AckRequest) - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
sendAckRequest sends an ack request to the server.
sendGetPartitionsRequest() - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
sendGetPartitionsRequest sends a getPartitions request to the server.
sendPendingRequest() - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
sendPendingRequest sends a pending request to the server.
sendReadRequest(ReadRequest, OutputObserver) - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit.Client
sendReadRequest sends a read request to the server.
sendReduceRequest(ReducerTestKit.TestReduceRequest) - Method in class io.numaproj.numaflow.reducer.ReducerTestKit.Client
sendReduceRequest sends a reduce request to the server.
sendRequest(DatumIterator) - Method in class io.numaproj.numaflow.sinker.SinkerTestKit.Client
Send request to the server.
sendRequest(String[], Datum) - Method in class io.numaproj.numaflow.mapper.MapperTestKit.Client
Send a request to the server.
sendRequest(String[], Datum) - Method in class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit.Client
Send a request to the server.
Server - Class in io.numaproj.numaflow.mapper
Server is the gRPC server for executing map operation.
Server - Class in io.numaproj.numaflow.mapstreamer
MapServer is the gRPC server for executing map operation.
Server - Class in io.numaproj.numaflow.reducer
Server is the gRPC server for executing reduce operation.
Server - Class in io.numaproj.numaflow.reducestreamer
Server is the gRPC server for executing reduce stream operation.
Server - Class in io.numaproj.numaflow.sessionreducer
Server is the gRPC server for executing session reduce operations.
Server - Class in io.numaproj.numaflow.sideinput
Server is the gRPC server for retrieving side input.
Server - Class in io.numaproj.numaflow.sinker
Server is the gRPC server for executing user defined sinks.
Server - Class in io.numaproj.numaflow.sourcer
Server is the gRPC server for reading from source.
Server - Class in io.numaproj.numaflow.sourcetransformer
Server is the gRPC server for executing source transformer operation.
Server(Mapper) - Constructor for class io.numaproj.numaflow.mapper.Server
constructor to create gRPC server.
Server(Mapper, GRPCConfig) - Constructor for class io.numaproj.numaflow.mapper.Server
constructor to create gRPC server with gRPC config.
Server(MapStreamer) - Constructor for class io.numaproj.numaflow.mapstreamer.Server
constructor to create sink gRPC server.
Server(MapStreamer, GRPCConfig) - Constructor for class io.numaproj.numaflow.mapstreamer.Server
constructor to create sink gRPC server with gRPC config.
Server(ReducerFactory<? extends Reducer>) - Constructor for class io.numaproj.numaflow.reducer.Server
constructor to create gRPC server.
Server(ReducerFactory<? extends Reducer>, GRPCConfig) - Constructor for class io.numaproj.numaflow.reducer.Server
constructor to create gRPC server with gRPC config.
Server(ReduceStreamerFactory<? extends ReduceStreamer>) - Constructor for class io.numaproj.numaflow.reducestreamer.Server
constructor to create gRPC server.
Server(ReduceStreamerFactory<? extends ReduceStreamer>, GRPCConfig) - Constructor for class io.numaproj.numaflow.reducestreamer.Server
constructor to create gRPC server with gRPC config.
Server(SessionReducerFactory<? extends SessionReducer>) - Constructor for class io.numaproj.numaflow.sessionreducer.Server
constructor to create gRPC server.
Server(SessionReducerFactory<? extends SessionReducer>, GRPCConfig) - Constructor for class io.numaproj.numaflow.sessionreducer.Server
constructor to create gRPC server with gRPC config.
Server(SideInputRetriever) - Constructor for class io.numaproj.numaflow.sideinput.Server
constructor to create gRPC server.
Server(SideInputRetriever, GRPCConfig) - Constructor for class io.numaproj.numaflow.sideinput.Server
constructor to create gRPC server with gRPC config.
Server(Sinker) - Constructor for class io.numaproj.numaflow.sinker.Server
constructor to create sink gRPC server.
Server(Sinker, GRPCConfig) - Constructor for class io.numaproj.numaflow.sinker.Server
constructor to create sink gRPC server with gRPC config.
Server(Sourcer) - Constructor for class io.numaproj.numaflow.sourcer.Server
constructor to create gRPC server.
Server(Sourcer, GRPCConfig) - Constructor for class io.numaproj.numaflow.sourcer.Server
constructor to create gRPC server with gRPC config.
Server(SourceTransformer) - Constructor for class io.numaproj.numaflow.sourcetransformer.Server
constructor to create gRPC server.
Server(SourceTransformer, GRPCConfig) - Constructor for class io.numaproj.numaflow.sourcetransformer.Server
constructor to create gRPC server with gRPC config.
SessionReducer - Class in io.numaproj.numaflow.sessionreducer.model
SessionReducer exposes methods for performing session reduce operations.
SessionReducer() - Constructor for class io.numaproj.numaflow.sessionreducer.model.SessionReducer
 
SessionReducerFactory<SessionReducerT extends SessionReducer> - Class in io.numaproj.numaflow.sessionreducer.model
ReduceStreamerFactory is the factory for SessionReducer.
SessionReducerFactory() - Constructor for class io.numaproj.numaflow.sessionreducer.model.SessionReducerFactory
 
setServerBuilder(ServerBuilder<?>) - Method in class io.numaproj.numaflow.mapper.Server
Sets the server builder.
setServerBuilder(ServerBuilder<?>) - Method in class io.numaproj.numaflow.mapstreamer.Server
Set server builder for testing.
setServerBuilder(ServerBuilder<?>) - Method in class io.numaproj.numaflow.sideinput.Server
Set server builder for testing.
setServerBuilder(ServerBuilder<?>) - Method in class io.numaproj.numaflow.sinker.Server
Sets the server builder.
setServerBuilder(ServerBuilder<?>) - Method in class io.numaproj.numaflow.sourcer.Server
Set server builder for testing.
setServerBuilder(ServerBuilder<?>) - Method in class io.numaproj.numaflow.sourcetransformer.Server
Set server builder for testing.
SIDE_INPUT_DIR - Static variable in class io.numaproj.numaflow.sideinput.Constants
 
SideInputRetriever - Class in io.numaproj.numaflow.sideinput
SideInputRetriever exposes method for retrieving side input.
SideInputRetriever() - Constructor for class io.numaproj.numaflow.sideinput.SideInputRetriever
 
Sinker - Class in io.numaproj.numaflow.sinker
Sinker exposes method for publishing messages to sink.
Sinker() - Constructor for class io.numaproj.numaflow.sinker.Sinker
 
SinkerTestKit - Class in io.numaproj.numaflow.sinker
SinkerTestKit is a test kit for testing Sinker implementations.
SinkerTestKit(Sinker) - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit
Create a new SinkerTestKit.
SinkerTestKit(Sinker, GRPCConfig) - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit
Create a new SinkerTestKit with the given Sinker and GRPCConfig.
SinkerTestKit.Client - Class in io.numaproj.numaflow.sinker
Client is a client for sending requests to the server.
SinkerTestKit.TestBlockingIterator - Class in io.numaproj.numaflow.sinker
TestBlockingIterator is a blocking queue based DatumIterator for testing.
SinkerTestKit.TestDatum - Class in io.numaproj.numaflow.sinker
TestDatum is a Datum for testing.
SinkerTestKit.TestListIterator - Class in io.numaproj.numaflow.sinker
TestListIterator is a list based DatumIterator for testing.
Sourcer - Class in io.numaproj.numaflow.sourcer
Sourcer exposes method for reading messages from source.
Sourcer() - Constructor for class io.numaproj.numaflow.sourcer.Sourcer
 
SourcerTestKit - Class in io.numaproj.numaflow.sourcer
SourcerTestKit is a test kit for testing Sourcer implementations.
SourcerTestKit(Sourcer) - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit
Create a new SourcerTestKit with the given Sourcer.
SourcerTestKit(Sourcer, GRPCConfig) - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit
Create a new SourcerTestKit with the given Sourcer and GRPCConfig.
SourcerTestKit.Client - Class in io.numaproj.numaflow.sourcer
SourcerClient is a client to send requests to the server.
SourcerTestKit.TestAckRequest - Class in io.numaproj.numaflow.sourcer
TestAckRequest is a simple implementation of AckRequest for testing.
SourcerTestKit.TestListBasedObserver - Class in io.numaproj.numaflow.sourcer
TestListBasedObserver is a simple list based implementation of OutputObserver for testing.
SourcerTestKit.TestReadRequest - Class in io.numaproj.numaflow.sourcer
TestReadRequest is a simple implementation of ReadRequest for testing.
SourceTransformer - Class in io.numaproj.numaflow.sourcetransformer
SourceTransformer exposes method for performing transform operation in the source.
SourceTransformer() - Constructor for class io.numaproj.numaflow.sourcetransformer.SourceTransformer
 
SourceTransformerTestKit - Class in io.numaproj.numaflow.sourcetransformer
SourceTransformerTestKit is a test kit for testing SourceTransformer implementations.
SourceTransformerTestKit(SourceTransformer) - Constructor for class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit
Create a new SourceTransformerTestKit with the given SourceTransformer.
SourceTransformerTestKit(SourceTransformer, GRPCConfig) - Constructor for class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit
Create a new SourceTransformerTestKit with the given SourceTransformer and GRPCConfig.
SourceTransformerTestKit.Client - Class in io.numaproj.numaflow.sourcetransformer
SourceTransformerClient is a client for sending requests to the source transformer server.
SourceTransformerTestKit.TestDatum - Class in io.numaproj.numaflow.sourcetransformer
TestDatum is a Datum for testing.
start() - Method in class io.numaproj.numaflow.mapper.Server
Starts the gRPC server and begins listening for requests.
start() - Method in class io.numaproj.numaflow.mapstreamer.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.reducer.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.reducestreamer.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.sessionreducer.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.sideinput.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.sinker.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.sourcer.Server
Start serving requests.
start() - Method in class io.numaproj.numaflow.sourcetransformer.Server
Start serving requests.
startServer() - Method in class io.numaproj.numaflow.mapper.MapperTestKit
Start the server.
startServer() - Method in class io.numaproj.numaflow.reducer.ReducerTestKit
startServer starts the server.
startServer() - Method in class io.numaproj.numaflow.sinker.SinkerTestKit
Start the server.
startServer() - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit
startServer starts the server.
startServer() - Method in class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit
Start the server.
stop() - Method in class io.numaproj.numaflow.mapper.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.mapstreamer.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.reducer.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.reducestreamer.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.sessionreducer.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.sideinput.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.sinker.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.sourcer.Server
Stop serving requests and shutdown resources.
stop() - Method in class io.numaproj.numaflow.sourcetransformer.Server
Stop serving requests and shutdown resources.
stopServer() - Method in class io.numaproj.numaflow.mapper.MapperTestKit
Stops the server.
stopServer() - Method in class io.numaproj.numaflow.reducer.ReducerTestKit
stopServer stops the server.
stopServer() - Method in class io.numaproj.numaflow.sinker.SinkerTestKit
Stop the server.
stopServer() - Method in class io.numaproj.numaflow.sourcer.SourcerTestKit
stopServer stops the server.
stopServer() - Method in class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit
Stops the server.

T

TestAckRequest() - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit.TestAckRequest
 
TestBlockingIterator() - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit.TestBlockingIterator
 
TestDatum() - Constructor for class io.numaproj.numaflow.mapper.MapperTestKit.TestDatum
 
TestDatum() - Constructor for class io.numaproj.numaflow.reducer.ReducerTestKit.TestDatum
 
TestDatum() - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit.TestDatum
 
TestDatum() - Constructor for class io.numaproj.numaflow.sourcetransformer.SourceTransformerTestKit.TestDatum
 
TestListBasedObserver() - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit.TestListBasedObserver
 
TestListIterator() - Constructor for class io.numaproj.numaflow.sinker.SinkerTestKit.TestListIterator
 
TestReadRequest() - Constructor for class io.numaproj.numaflow.sourcer.SourcerTestKit.TestReadRequest
 
TestReduceRequest() - Constructor for class io.numaproj.numaflow.reducer.ReducerTestKit.TestReduceRequest
 
toDrop() - Static method in class io.numaproj.numaflow.mapper.Message
creates a Message which will be dropped
toDrop() - Static method in class io.numaproj.numaflow.mapstreamer.Message
creates a Message which will be dropped
toDrop() - Static method in class io.numaproj.numaflow.reducer.Message
creates a Message which will be dropped
toDrop() - Static method in class io.numaproj.numaflow.reducestreamer.model.Message
creates a Message which will be dropped
toDrop() - Static method in class io.numaproj.numaflow.sessionreducer.model.Message
creates a Message which will be dropped
toDrop(Instant) - Static method in class io.numaproj.numaflow.sourcetransformer.Message
creates a Message which will be dropped.

U

UniqueIdGenerator - Class in io.numaproj.numaflow.sessionreducer
UniqueIdGenerator is a utility class to generate a unique id for a keyed session window.

V

valueOf(String) - Static method in enum io.numaproj.numaflow.sessionreducer.ActorRequestType
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.numaproj.numaflow.sessionreducer.ActorRequestType
Returns an array containing the constants of this enum type, in the order they are declared.
A C D E G H I M N O P R S T U V 
All Classes All Packages