Interface | Description |
---|---|
DataStreams.OutputChunkConsumer<T> |
A callback which is invoked whenever the
DataStreams.outbound(org.apache.beam.sdk.fn.stream.DataStreams.OutputChunkConsumer<org.apache.beam.vendor.grpc.v1p36p0.com.google.protobuf.ByteString>) OutputStream becomes full. |
OutboundObserverFactory.BasicFactory<ReqT,RespT> |
Creates an outbound observer for the given inbound observer.
|
PrefetchableIterable<T> |
An
Iterable that returns PrefetchableIterator s. |
PrefetchableIterator<T> |
Iterator that supports prefetching the next set of records. |
Class | Description |
---|---|
AdvancingPhaser |
A
Phaser which never terminates. |
BufferingStreamObserver<T> |
A thread safe
StreamObserver which uses a bounded queue to pass elements to a processing
thread responsible for interacting with the underlying CallStreamObserver . |
DataStreams |
DataStreams.DataStreamDecoder treats multiple ByteString s as a single input stream decoding
values with the supplied iterator. |
DataStreams.BlockingQueueIterator<T> |
Allows for one or more writing threads to append values to this iterator while one reading
thread reads values.
|
DataStreams.DataStreamDecoder<T> |
An adapter which converts an
InputStream to a PrefetchableIterator of T
values using the specified Coder . |
DataStreams.ElementDelimitedOutputStream |
An adapter which wraps an
DataStreams.OutputChunkConsumer as an OutputStream . |
DirectStreamObserver<T> |
A
StreamObserver which uses synchronization on the underlying CallStreamObserver
to provide thread safety. |
ForwardingClientResponseObserver<ReqT,RespT> |
A
ClientResponseObserver which delegates all StreamObserver calls. |
OutboundObserverFactory |
Creates factories which determine an underlying
StreamObserver implementation to use in
to interact with fn execution APIs. |
PrefetchableIterables |
This class contains static utility functions that operate on or return objects of type
PrefetchableIterable . |
PrefetchableIterators | |
SynchronizedStreamObserver<V> |
A
StreamObserver which provides synchronous access access to an underlying StreamObserver . |