Package org.apache.beam.sdk.fn.stream
package org.apache.beam.sdk.fn.stream
gRPC stream management.
-
ClassDescriptionA
Phaser
which never terminates.A thread safeStreamObserver
which uses a bounded queue to pass elements to a processing thread responsible for interacting with the underlyingCallStreamObserver
.DataStreams.DataStreamDecoder
treats multipleByteString
s as a single input stream decoding values with the supplied iterator.An adapter which converts anInputStream
to aPrefetchableIterator
ofT
values using the specifiedCoder
.An adapter which wraps anDataStreams.OutputChunkConsumer
as anOutputStream
.A callback which is invoked whenever theDataStreams.outbound(org.apache.beam.sdk.fn.stream.DataStreams.OutputChunkConsumer<org.apache.beam.vendor.grpc.v1p69p0.com.google.protobuf.ByteString>)
OutputStream
becomes full.AStreamObserver
which uses synchronization on the underlyingCallStreamObserver
to provide thread safety.ForwardingClientResponseObserver<ReqT,RespT> AClientResponseObserver
which delegates allStreamObserver
calls.Creates factories which determine an underlyingStreamObserver
implementation to use in to interact with fn execution APIs.OutboundObserverFactory.BasicFactory<ReqT,RespT> Creates an outbound observer for the given inbound observer.AnIterable
that returnsPrefetchableIterator
s.This class contains static utility functions that operate on or return objects of typePrefetchableIterable
.A default implementation that caches an iterator to be returned whenPrefetchableIterables.Default.prefetch()
is invoked.Iterator
that supports prefetching the next set of records.AStreamObserver
which provides synchronous access access to an underlyingStreamObserver
.