Modifier and Type | Method and Description |
---|---|
protected abstract void |
BinaryOutputFormat.serialize(T record,
DataOutputView dataOutput) |
protected void |
SerializedOutputFormat.serialize(T record,
DataOutputView dataOutputView) |
void |
BlockInfo.write(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
UnloadableDummyTypeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
CompositeSerializer.copy(DataInputView source,
DataOutputView target) |
abstract void |
TypeSerializer.copy(DataInputView source,
DataOutputView target)
Copies exactly one record from the source input view to the target output view.
|
void |
SingleThreadAccessCheckingTypeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
UnloadableDummyTypeSerializer.serialize(T record,
DataOutputView target) |
void |
CompositeSerializer.serialize(T record,
DataOutputView target) |
abstract void |
TypeSerializer.serialize(T record,
DataOutputView target)
Serializes the given record to the given target output view.
|
void |
SingleThreadAccessCheckingTypeSerializer.serialize(T record,
DataOutputView target) |
void |
NestedSerializersSnapshotDelegate.writeNestedSerializerSnapshots(DataOutputView out)
Writes the composite snapshot of all the contained serializers.
|
protected void |
CompositeTypeSerializerSnapshot.writeOuterSnapshot(DataOutputView out)
Writes the outer snapshot, i.e. any information beyond the nested serializers of the outer
serializer.
|
static <T> void |
TypeSerializerSnapshotSerializationUtil.writeSerializerSnapshot(DataOutputView out,
TypeSerializerSnapshot<T> serializerSnapshot)
Writes a
TypeSerializerSnapshot to the provided data output view. |
void |
SimpleTypeSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
TypeSerializerSnapshot.writeSnapshot(DataOutputView out)
Writes the serializer snapshot to the provided
DataOutputView . |
void |
GenericTypeSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
CompositeTypeSerializerSnapshot.writeSnapshot(DataOutputView out) |
static void |
TypeSerializerSnapshot.writeVersionedSnapshot(DataOutputView out,
TypeSerializerSnapshot<?> snapshot)
Writes the given snapshot to the out stream.
|
abstract void |
TypeComparator.writeWithKeyNormalization(T record,
DataOutputView target)
Writes the record in such a fashion that all keys are normalizing and at the beginning of the
serialized data.
|
Modifier and Type | Method and Description |
---|---|
void |
EnumSerializer.copy(DataInputView source,
DataOutputView target) |
void |
IntSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ByteSerializer.copy(DataInputView source,
DataOutputView target) |
void |
SqlDateSerializer.copy(DataInputView source,
DataOutputView target) |
void |
DateSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ByteValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ListSerializer.copy(DataInputView source,
DataOutputView target) |
void |
SqlTimeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
LocalTimeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BooleanValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
LocalDateTimeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
IntValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
FloatValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
MapSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BigDecSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BigIntSerializer.copy(DataInputView source,
DataOutputView target) |
void |
SqlTimestampSerializer.copy(DataInputView source,
DataOutputView target) |
void |
CharSerializer.copy(DataInputView source,
DataOutputView target) |
void |
DoubleValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BooleanSerializer.copy(DataInputView source,
DataOutputView target) |
void |
StringValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
FloatSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ShortValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
CharValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ShortSerializer.copy(DataInputView source,
DataOutputView target) |
void |
LocalDateSerializer.copy(DataInputView source,
DataOutputView target) |
void |
DoubleSerializer.copy(DataInputView source,
DataOutputView target) |
void |
GenericArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
LongSerializer.copy(DataInputView source,
DataOutputView target) |
void |
InstantSerializer.copy(DataInputView source,
DataOutputView target) |
void |
VoidSerializer.copy(DataInputView source,
DataOutputView target) |
void |
LongValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
StringSerializer.copy(DataInputView source,
DataOutputView target) |
void |
NullValueSerializer.copy(DataInputView source,
DataOutputView target) |
static boolean |
BigIntSerializer.copyBigInteger(DataInputView source,
DataOutputView target) |
void |
BigDecSerializer.serialize(BigDecimal record,
DataOutputView target) |
void |
BigIntSerializer.serialize(BigInteger record,
DataOutputView target) |
void |
BooleanSerializer.serialize(Boolean record,
DataOutputView target) |
void |
BooleanValueSerializer.serialize(BooleanValue record,
DataOutputView target) |
void |
ByteSerializer.serialize(Byte record,
DataOutputView target) |
void |
ByteValueSerializer.serialize(ByteValue record,
DataOutputView target) |
void |
GenericArraySerializer.serialize(C[] value,
DataOutputView target) |
void |
CharSerializer.serialize(Character record,
DataOutputView target) |
void |
CharValueSerializer.serialize(CharValue record,
DataOutputView target) |
void |
SqlDateSerializer.serialize(Date record,
DataOutputView target) |
void |
DateSerializer.serialize(Date record,
DataOutputView target) |
void |
DoubleSerializer.serialize(Double record,
DataOutputView target) |
void |
DoubleValueSerializer.serialize(DoubleValue record,
DataOutputView target) |
void |
FloatSerializer.serialize(Float record,
DataOutputView target) |
void |
FloatValueSerializer.serialize(FloatValue record,
DataOutputView target) |
void |
InstantSerializer.serialize(Instant record,
DataOutputView target) |
void |
IntSerializer.serialize(Integer record,
DataOutputView target) |
void |
IntValueSerializer.serialize(IntValue record,
DataOutputView target) |
void |
ListSerializer.serialize(List<T> list,
DataOutputView target) |
void |
LocalDateSerializer.serialize(LocalDate record,
DataOutputView target) |
void |
LocalDateTimeSerializer.serialize(LocalDateTime record,
DataOutputView target) |
void |
LocalTimeSerializer.serialize(LocalTime record,
DataOutputView target) |
void |
LongSerializer.serialize(Long record,
DataOutputView target) |
void |
LongValueSerializer.serialize(LongValue record,
DataOutputView target) |
void |
MapSerializer.serialize(Map<K,V> map,
DataOutputView target) |
void |
NullValueSerializer.serialize(NullValue record,
DataOutputView target) |
void |
ShortSerializer.serialize(Short record,
DataOutputView target) |
void |
ShortValueSerializer.serialize(ShortValue record,
DataOutputView target) |
void |
StringSerializer.serialize(String record,
DataOutputView target) |
void |
StringValueSerializer.serialize(StringValue record,
DataOutputView target) |
void |
EnumSerializer.serialize(T record,
DataOutputView target) |
void |
SqlTimeSerializer.serialize(Time record,
DataOutputView target) |
void |
SqlTimestampSerializer.serialize(Timestamp record,
DataOutputView target) |
void |
VoidSerializer.serialize(Void record,
DataOutputView target) |
static void |
BigIntSerializer.writeBigInteger(BigInteger record,
DataOutputView target) |
protected void |
GenericArraySerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
void |
EnumSerializer.EnumSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
GenericArraySerializerConfigSnapshot.writeSnapshot(DataOutputView out)
Deprecated.
|
void |
BooleanValueComparator.writeWithKeyNormalization(BooleanValue record,
DataOutputView target) |
void |
ByteValueComparator.writeWithKeyNormalization(ByteValue record,
DataOutputView target) |
void |
CharValueComparator.writeWithKeyNormalization(CharValue record,
DataOutputView target) |
void |
DoubleValueComparator.writeWithKeyNormalization(DoubleValue record,
DataOutputView target) |
void |
FloatValueComparator.writeWithKeyNormalization(FloatValue record,
DataOutputView target) |
void |
IntValueComparator.writeWithKeyNormalization(IntValue record,
DataOutputView target) |
void |
LocalDateComparator.writeWithKeyNormalization(LocalDate record,
DataOutputView target) |
void |
LocalDateTimeComparator.writeWithKeyNormalization(LocalDateTime record,
DataOutputView target) |
void |
LongValueComparator.writeWithKeyNormalization(LongValue record,
DataOutputView target) |
void |
NullValueComparator.writeWithKeyNormalization(NullValue record,
DataOutputView target) |
void |
ShortValueComparator.writeWithKeyNormalization(ShortValue record,
DataOutputView target) |
void |
StringValueComparator.writeWithKeyNormalization(StringValue record,
DataOutputView target) |
void |
BasicTypeComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
BytePrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
IntPrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
FloatPrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
ShortPrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
CharPrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
DoublePrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
BooleanPrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
StringArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
LongPrimitiveArraySerializer.copy(DataInputView source,
DataOutputView target) |
void |
BooleanPrimitiveArraySerializer.serialize(boolean[] record,
DataOutputView target) |
void |
BytePrimitiveArraySerializer.serialize(byte[] record,
DataOutputView target) |
void |
CharPrimitiveArraySerializer.serialize(char[] record,
DataOutputView target) |
void |
DoublePrimitiveArraySerializer.serialize(double[] record,
DataOutputView target) |
void |
FloatPrimitiveArraySerializer.serialize(float[] record,
DataOutputView target) |
void |
IntPrimitiveArraySerializer.serialize(int[] record,
DataOutputView target) |
void |
LongPrimitiveArraySerializer.serialize(long[] record,
DataOutputView target) |
void |
ShortPrimitiveArraySerializer.serialize(short[] record,
DataOutputView target) |
void |
StringArraySerializer.serialize(String[] record,
DataOutputView target) |
void |
PrimitiveArrayComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
protected void |
TypeSerializerOutputFormat.serialize(T record,
DataOutputView dataOutput)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected DataOutputView |
DataOutputViewStream.outputView |
Modifier and Type | Method and Description |
---|---|
void |
WritableSerializer.copy(DataInputView source,
DataOutputView target) |
void |
PojoSerializer.copy(DataInputView source,
DataOutputView target) |
void |
Tuple0Serializer.copy(DataInputView source,
DataOutputView target) |
void |
CopyableValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
RowSerializer.copy(DataInputView source,
DataOutputView target) |
void |
TupleSerializerBase.copy(DataInputView source,
DataOutputView target) |
void |
NullableSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ValueSerializer.copy(DataInputView source,
DataOutputView target) |
void |
EitherSerializer.copy(DataInputView source,
DataOutputView target) |
static void |
MaskUtils.readIntoAndCopyMask(DataInputView source,
DataOutputView target,
boolean[] mask) |
static void |
MaskUtils.readIntoAndCopyMask(DataInputView source,
DataOutputView target,
boolean[] mask,
int len) |
void |
EitherSerializer.serialize(Either<L,R> record,
DataOutputView target) |
void |
RowSerializer.serialize(Row record,
DataOutputView target) |
void |
WritableSerializer.serialize(T record,
DataOutputView target) |
void |
PojoSerializer.serialize(T value,
DataOutputView target) |
void |
CopyableValueSerializer.serialize(T value,
DataOutputView target) |
void |
NullableSerializer.serialize(T record,
DataOutputView target) |
void |
TupleSerializer.serialize(T value,
DataOutputView target) |
void |
ValueSerializer.serialize(T value,
DataOutputView target) |
void |
Tuple0Serializer.serialize(Tuple0 record,
DataOutputView target) |
static void |
MaskUtils.writeMask(boolean[] mask,
DataOutputView target) |
static void |
MaskUtils.writeMask(boolean[] mask,
int len,
DataOutputView target) |
protected void |
TupleSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
protected void |
RowSerializer.RowSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
protected void |
NullableSerializer.NullableSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
void |
PojoSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
EitherSerializerSnapshot.writeSnapshot(DataOutputView out)
Deprecated.
|
void |
RowComparator.writeWithKeyNormalization(Row record,
DataOutputView target) |
void |
WritableComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
void |
NullAwareComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
void |
TupleComparatorBase.writeWithKeyNormalization(T record,
DataOutputView target) |
void |
ValueComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
void |
CopyableValueComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
void |
PojoComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
void |
GenericTypeComparator.writeWithKeyNormalization(T record,
DataOutputView target) |
Constructor and Description |
---|
DataOutputViewStream(DataOutputView outputView) |
Modifier and Type | Method and Description |
---|---|
void |
KryoSerializer.copy(DataInputView source,
DataOutputView target) |
void |
KryoSerializer.serialize(T record,
DataOutputView target) |
void |
KryoSerializerSnapshot.writeSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
protected void |
ScalaCaseClassSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
protected void |
TraversableSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
protected void |
Tuple2CaseClassSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
DeweyNumber.DeweyNumberSerializer.copy(DataInputView source,
DataOutputView target) |
void |
NFA.NFASerializer.copy(DataInputView source,
DataOutputView target)
Deprecated.
|
void |
SharedBuffer.SharedBufferSerializer.copy(DataInputView source,
DataOutputView target) |
void |
NFAStateSerializer.copy(DataInputView source,
DataOutputView target) |
void |
DeweyNumber.DeweyNumberSerializer.serialize(DeweyNumber record,
DataOutputView target) |
void |
NFA.NFASerializer.serialize(NFA.MigratedNFA<T> record,
DataOutputView target)
Deprecated.
|
void |
NFAStateSerializer.serialize(NFAState record,
DataOutputView target) |
void |
SharedBuffer.SharedBufferSerializer.serialize(SharedBuffer<V> record,
DataOutputView target) |
protected void |
NFAStateSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
EventId.EventIdSerializer.copy(DataInputView source,
DataOutputView target) |
void |
SharedBufferNodeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
SharedBufferNode.SharedBufferNodeSerializer.copy(DataInputView source,
DataOutputView target)
Deprecated.
|
void |
Lockable.LockableTypeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
NodeId.NodeIdSerializer.copy(DataInputView source,
DataOutputView target) |
void |
SharedBufferEdge.SharedBufferEdgeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
EventId.EventIdSerializer.serialize(EventId record,
DataOutputView target) |
void |
Lockable.LockableTypeSerializer.serialize(Lockable<E> record,
DataOutputView target) |
void |
NodeId.NodeIdSerializer.serialize(NodeId record,
DataOutputView target) |
void |
SharedBufferEdge.SharedBufferEdgeSerializer.serialize(SharedBufferEdge record,
DataOutputView target) |
void |
SharedBufferNodeSerializer.serialize(SharedBufferNode record,
DataOutputView target) |
void |
SharedBufferNode.SharedBufferNodeSerializer.serialize(SharedBufferNode record,
DataOutputView target)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
DelegatingConfiguration.write(DataOutputView out) |
void |
Configuration.write(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
static void |
Path.serializeToDataOutputView(Path path,
DataOutputView out)
Serialize the path to
DataInputView . |
void |
Path.write(DataOutputView out)
Deprecated.
the method is deprecated since Flink 1.19 because Path will no longer implement
IOReadableWritable in future versions. Please use serializeToDataOutputView instead. |
Modifier and Type | Method and Description |
---|---|
void |
SimpleVersionedSerializerTypeSerializerProxy.copy(DataInputView source,
DataOutputView target) |
void |
SimpleVersionedSerializerTypeSerializerProxy.serialize(T record,
DataOutputView target) |
void |
VersionedIOReadableWritable.write(DataOutputView out) |
void |
PostVersionedIOReadableWritable.write(DataOutputView out) |
void |
IOReadableWritable.write(DataOutputView out)
Writes the object's internal data to the given data output view.
|
static <T> void |
SimpleVersionedSerialization.writeVersionAndSerialize(SimpleVersionedSerializer<T> serializer,
T datum,
DataOutputView out)
Serializes the version and datum into a stream.
|
static <T> void |
SimpleVersionedSerialization.writeVersionAndSerializeList(SimpleVersionedSerializer<T> serializer,
List<T> data,
DataOutputView out)
Serializes the version and data into a stream.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SeekableDataOutputView
Interface marking a
DataOutputView as seekable. |
Modifier and Type | Class and Description |
---|---|
class |
DataOutputSerializer
A simple and efficient serializer for the
DataOutput interface. |
class |
DataOutputViewStreamWrapper
Utility class that turns an
OutputStream into a DataOutputView . |
Modifier and Type | Method and Description |
---|---|
void |
AvroSerializer.copy(DataInputView source,
DataOutputView target) |
void |
AvroSerializer.serialize(T value,
DataOutputView target) |
void |
AvroSerializerSnapshot.writeSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
VoidNamespaceSerializer.copy(DataInputView source,
DataOutputView target) |
void |
VoidNamespaceSerializer.serialize(VoidNamespace record,
DataOutputView target) |
Modifier and Type | Class and Description |
---|---|
class |
FileChannelOutputView
A
DataOutputView that is backed by a BlockChannelWriter , making it effectively a data output stream. |
class |
RandomAccessOutputView |
class |
SimpleCollectingOutputView
The list with the full segments contains at any point all completely full segments, plus the
segment that is currently filled.
|
class |
SpillingBuffer
An output view that buffers written data in memory pages and spills them when they are full.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractChannelWriterOutputView
A
DataOutputView that is backed by a FileIOChannel ,
making it effectively a data output stream. |
class |
ChannelWriterOutputView
A
DataOutputView that is backed by a BlockChannelWriter , making it effectively a data output stream. |
Modifier and Type | Method and Description |
---|---|
void |
RecoveryMetadata.write(DataOutputView out) |
void |
CheckpointBarrier.write(DataOutputView out) |
void |
EndOfSegmentEvent.write(DataOutputView out) |
void |
EndOfSuperstepEvent.write(DataOutputView out) |
void |
EndOfPartitionEvent.write(DataOutputView out) |
void |
EndOfData.write(DataOutputView out) |
void |
SubtaskConnectionDescriptor.write(DataOutputView out) |
void |
CancelCheckpointMarker.write(DataOutputView out) |
void |
EventAnnouncement.write(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
EndOfChannelStateEvent.write(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
DataOutputView |
BlockingBackChannel.getWriteEnd()
Called by iteration tail to save the output of the current superstep.
|
Modifier and Type | Method and Description |
---|---|
void |
WorkerDoneEvent.write(DataOutputView out) |
void |
IterationEventWithAggregators.write(DataOutputView out) |
void |
TerminationEvent.write(DataOutputView out) |
Modifier and Type | Class and Description |
---|---|
class |
SerializedUpdateBuffer
AbstractPagedOutputView used by the BlockingBackChannel for transmitting
superstep results. |
Constructor and Description |
---|
WorksetUpdateOutputCollector(DataOutputView outputView,
TypeSerializer<T> serializer) |
WorksetUpdateOutputCollector(DataOutputView outputView,
TypeSerializer<T> serializer,
Collector<T> delegate) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPagedOutputView
The base class for all output views that are backed by multiple memory pages.
|
Modifier and Type | Class and Description |
---|---|
protected static class |
HashPartition.BuildSideBuffer |
Modifier and Type | Method and Description |
---|---|
void |
ReusingDeserializationDelegate.write(DataOutputView out) |
void |
SerializationDelegate.write(DataOutputView out) |
void |
NonReusingDeserializationDelegate.write(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
ArrayListSerializer.copy(DataInputView source,
DataOutputView target) |
void |
JavaSerializer.copy(DataInputView source,
DataOutputView target) |
void |
VoidNamespaceSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ArrayListSerializer.serialize(ArrayList<T> list,
DataOutputView target) |
void |
JavaSerializer.serialize(T record,
DataOutputView target) |
void |
VoidNamespaceSerializer.serialize(VoidNamespace record,
DataOutputView target) |
void |
KeyedBackendSerializationProxy.write(DataOutputView out) |
void |
OperatorBackendSerializationProxy.write(DataOutputView out) |
void |
KeyGroupPartitioner.ElementWriterFunction.writeElement(T element,
DataOutputView dov)
This method defines how to write a single element to the output.
|
static void |
CompositeKeySerializationUtils.writeKeyGroup(int keyGroup,
int keyGroupPrefixBytes,
DataOutputView keySerializationDateDataOutputView) |
void |
StateSnapshot.StateKeyGroupWriter.writeStateInKeyGroup(DataOutputView dov,
int keyGroupId)
Writes the data for the specified key-group to the output.
|
static void |
CompositeKeySerializationUtils.writeVariableIntBytes(int value,
DataOutputView keySerializationDateDataOutputView) |
Modifier and Type | Method and Description |
---|---|
void |
CopyOnWriteSkipListStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
abstract void |
StateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer)
Writes the state in this snapshot to output.
|
void |
CopyOnWriteStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
Modifier and Type | Method and Description |
---|---|
void |
StateMetaInfoWriter.writeStateMetaInfoSnapshot(StateMetaInfoSnapshot snapshot,
DataOutputView outputView)
Writes the given snapshot to the output view.
|
Modifier and Type | Method and Description |
---|---|
void |
StateChangeLogger.valueElementAdded(ThrowingConsumer<DataOutputView,IOException> dataSerializer,
Namespace ns)
State element added, such as append of a single element to a list.
|
void |
StateChangeLogger.valueElementAddedOrUpdated(ThrowingConsumer<DataOutputView,IOException> dataSerializer,
Namespace ns)
State element added or updated, such as put into a map.
|
void |
StateChangeLogger.valueElementRemoved(ThrowingConsumer<DataOutputView,IOException> dataSerializer,
Namespace ns)
State element removed, such mapping removal from a map.
|
Modifier and Type | Method and Description |
---|---|
void |
CoGroupedStreams.UnionSerializer.copy(DataInputView source,
DataOutputView target) |
void |
CoGroupedStreams.UnionSerializer.serialize(CoGroupedStreams.TaggedUnion<T1,T2> record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
TwoPhaseCommitSinkFunction.StateSerializer.copy(DataInputView source,
DataOutputView target) |
void |
TwoPhaseCommitSinkFunction.StateSerializer.serialize(TwoPhaseCommitSinkFunction.State<TXN,CONTEXT> record,
DataOutputView target) |
protected void |
TwoPhaseCommitSinkFunction.StateSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
TimerSerializer.copy(DataInputView source,
DataOutputView target) |
void |
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer.copy(DataInputView source,
DataOutputView target) |
void |
TimerSerializer.serialize(TimerHeapInternalTimer<K,N> record,
DataOutputView target) |
void |
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer.serialize(TimerHeapInternalTimer<K,N> record,
DataOutputView target) |
void |
InternalTimerServiceSerializationProxy.write(DataOutputView out) |
void |
InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter.writeTimersSnapshot(DataOutputView out)
Writes the timers snapshot to the output view.
|
Modifier and Type | Method and Description |
---|---|
void |
IntervalJoinOperator.BufferEntrySerializer.copy(DataInputView source,
DataOutputView target) |
void |
IntervalJoinOperator.BufferEntrySerializer.serialize(IntervalJoinOperator.BufferEntry<T> record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
CollectCoordinationRequest.serialize(DataOutputView outView) |
void |
CollectCoordinationResponse.serialize(DataOutputView outView) |
Modifier and Type | Method and Description |
---|---|
void |
FixedLengthByteKeyAndValueComparator.writeWithKeyNormalization(Tuple2<byte[],INPUT> record,
DataOutputView target) |
void |
VariableLengthByteKeyAndValueComparator.writeWithKeyNormalization(Tuple2<byte[],INPUT> record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
ByteArrayWrapperSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ByteArrayWrapperSerializer.serialize(ByteArrayWrapper record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
TimeWindow.Serializer.copy(DataInputView source,
DataOutputView target) |
void |
GlobalWindow.Serializer.copy(DataInputView source,
DataOutputView target) |
void |
GlobalWindow.Serializer.serialize(GlobalWindow record,
DataOutputView target) |
void |
TimeWindow.Serializer.serialize(TimeWindow record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
StreamElementSerializer.copy(DataInputView source,
DataOutputView target) |
void |
StreamElementSerializer.serialize(StreamElement value,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
StatefulComplexPayloadSerializer.copy(DataInputView source,
DataOutputView target) |
void |
StatefulComplexPayloadSerializer.serialize(ComplexPayload record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
static void |
BinarySegmentUtils.copyToView(MemorySegment[] segments,
int offset,
int sizeInBytes,
DataOutputView target)
Copy bytes of segments to output view.
|
Modifier and Type | Method and Description |
---|---|
void |
NullSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ListViewSerializer.copy(DataInputView source,
DataOutputView target)
Deprecated.
|
void |
NullAwareMapSerializer.copy(DataInputView source,
DataOutputView target)
Deprecated.
|
void |
MapViewSerializer.copy(DataInputView source,
DataOutputView target)
Deprecated.
|
void |
ListViewSerializer.serialize(ListView<T> record,
DataOutputView target)
Deprecated.
|
void |
NullAwareMapSerializer.serialize(Map<K,V> map,
DataOutputView target)
Deprecated.
|
void |
MapViewSerializer.serialize(MapView<K,V> record,
DataOutputView target)
Deprecated.
|
void |
NullSerializer.serialize(Object record,
DataOutputView target) |
Modifier and Type | Class and Description |
---|---|
protected static class |
BinaryHashPartition.BuildSideBuffer
Build side buffer.
|
Modifier and Type | Class and Description |
---|---|
class |
CompressedHeaderlessChannelWriterOutputView
A
DataOutputView that is backed by a FileIOChannel ,
making it effectively a data output stream. |
class |
HeaderlessChannelWriterOutputView
A
DataOutputView that is backed by a BlockChannelWriter , making it effectively a data output stream. |
Modifier and Type | Method and Description |
---|---|
void |
CountWindow.Serializer.copy(DataInputView source,
DataOutputView target) |
void |
TimeWindow.Serializer.copy(DataInputView source,
DataOutputView target) |
void |
CountWindow.Serializer.serialize(CountWindow record,
DataOutputView target) |
void |
TimeWindow.Serializer.serialize(TimeWindow record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
void |
ExternalSerializer.copy(DataInputView source,
DataOutputView target) |
void |
RawValueDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
DecimalDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
LinkedListSerializer.copy(DataInputView source,
DataOutputView target) |
void |
WindowKeySerializer.copy(DataInputView source,
DataOutputView target) |
void |
TimestampDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
MapDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
StringDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BinaryRowDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
RowDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ArrayDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BinaryRowDataSerializer.copyFromPagesToView(AbstractPagedInputView source,
DataOutputView target)
Copy a binaryRow which stored in paged input view to output view.
|
void |
ArrayDataSerializer.serialize(ArrayData record,
DataOutputView target) |
void |
BinaryRowDataSerializer.serialize(BinaryRowData record,
DataOutputView target) |
void |
DecimalDataSerializer.serialize(DecimalData record,
DataOutputView target) |
void |
ExternalSerializer.serialize(E record,
DataOutputView target) |
void |
LinkedListSerializer.serialize(LinkedList<T> list,
DataOutputView target) |
void |
MapDataSerializer.serialize(MapData record,
DataOutputView target) |
void |
RawValueDataSerializer.serialize(RawValueData<T> record,
DataOutputView target) |
void |
RowDataSerializer.serialize(RowData row,
DataOutputView target) |
void |
StringDataSerializer.serialize(StringData record,
DataOutputView target) |
void |
TimestampDataSerializer.serialize(TimestampData record,
DataOutputView target) |
void |
WindowKeySerializer.serialize(WindowKey record,
DataOutputView target) |
protected void |
ExternalSerializer.ExternalSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
protected void |
LinkedListSerializer.LinkedListSerializerSnapshot.writeOuterSnapshot(DataOutputView out) |
void |
SortedMapSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
DecimalDataSerializer.DecimalSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
TimestampDataSerializer.TimestampDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
MapDataSerializer.MapDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
RowDataSerializer.RowDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
ArrayDataSerializer.ArrayDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
void |
DateSerializer.copy(DataInputView source,
DataOutputView target) |
void |
TimeSerializer.copy(DataInputView source,
DataOutputView target) |
void |
DecimalDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
BigDecSerializer.copy(DataInputView source,
DataOutputView target) |
void |
TimestampSerializer.copy(DataInputView source,
DataOutputView target) |
void |
MapDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
RowDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
StringSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ArrayDataSerializer.copy(DataInputView source,
DataOutputView target) |
void |
ArrayDataSerializer.serialize(ArrayData array,
DataOutputView target) |
void |
BigDecSerializer.serialize(BigDecimal record,
DataOutputView target) |
void |
DateSerializer.serialize(Date record,
DataOutputView target) |
void |
DecimalDataSerializer.serialize(DecimalData record,
DataOutputView target) |
void |
MapDataSerializer.serialize(MapData map,
DataOutputView target) |
void |
RowDataSerializer.serialize(RowData row,
DataOutputView target) |
void |
StringSerializer.serialize(String record,
DataOutputView target) |
void |
TimeSerializer.serialize(Time record,
DataOutputView target) |
void |
TimestampSerializer.serialize(Timestamp record,
DataOutputView target) |
void |
DecimalDataSerializer.DecimalSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
TimestampSerializer.TimestampSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
MapDataSerializer.BaseMapSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
RowDataSerializer.RowDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
void |
ArrayDataSerializer.ArrayDataSerializerSnapshot.writeSnapshot(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
static void |
SegmentsUtil.copyToView(MemorySegment[] segments,
int offset,
int sizeInBytes,
DataOutputView target)
Copy bytes of segments to output view.
|
Modifier and Type | Method and Description |
---|---|
void |
CharValue.copy(DataInputView source,
DataOutputView target) |
void |
Record.copy(DataInputView source,
DataOutputView target) |
void |
BooleanValue.copy(DataInputView source,
DataOutputView target) |
void |
DoubleValue.copy(DataInputView source,
DataOutputView target) |
void |
FloatValue.copy(DataInputView source,
DataOutputView target) |
void |
CopyableValue.copy(DataInputView source,
DataOutputView target)
Copies the next serialized instance from
source to target . |
void |
StringValue.copy(DataInputView in,
DataOutputView target) |
void |
IntValue.copy(DataInputView source,
DataOutputView target) |
void |
ShortValue.copy(DataInputView source,
DataOutputView target) |
void |
LongValue.copy(DataInputView source,
DataOutputView target) |
void |
NullValue.copy(DataInputView source,
DataOutputView target) |
void |
ByteValue.copy(DataInputView source,
DataOutputView target) |
long |
Record.serialize(DataOutputView target)
Writes this record to the given output view.
|
void |
CharValue.write(DataOutputView out) |
void |
ListValue.write(DataOutputView out) |
void |
Record.write(DataOutputView out) |
void |
BooleanValue.write(DataOutputView out) |
void |
DoubleValue.write(DataOutputView out) |
void |
FloatValue.write(DataOutputView out) |
void |
MapValue.write(DataOutputView out) |
void |
StringValue.write(DataOutputView out) |
void |
IntValue.write(DataOutputView out) |
void |
ShortValue.write(DataOutputView out) |
void |
LongValue.write(DataOutputView out) |
void |
NullValue.write(DataOutputView out) |
void |
ByteValue.write(DataOutputView out) |
Modifier and Type | Method and Description |
---|---|
static void |
StringUtils.writeNullableString(String str,
DataOutputView out)
Writes a String to the given output.
|
static <K,V> void |
LinkedOptionalMapSerializer.writeOptionalMap(DataOutputView out,
LinkedOptionalMap<K,V> map,
BiConsumerWithException<DataOutputView,K,IOException> keyWriter,
BiConsumerWithException<DataOutputView,V,IOException> valueWriter) |
static void |
StringUtils.writeString(String str,
DataOutputView out)
Writes a String to the given output.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> void |
LinkedOptionalMapSerializer.writeOptionalMap(DataOutputView out,
LinkedOptionalMap<K,V> map,
BiConsumerWithException<DataOutputView,K,IOException> keyWriter,
BiConsumerWithException<DataOutputView,V,IOException> valueWriter) |
static <K,V> void |
LinkedOptionalMapSerializer.writeOptionalMap(DataOutputView out,
LinkedOptionalMap<K,V> map,
BiConsumerWithException<DataOutputView,K,IOException> keyWriter,
BiConsumerWithException<DataOutputView,V,IOException> valueWriter) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.