Package | Description |
---|---|
org.apache.flink.streaming.api.operators.co |
Modifier and Type | Method and Description |
---|---|
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.copy(IntervalJoinOperator.BufferEntry<T> from) |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.copy(IntervalJoinOperator.BufferEntry<T> from,
IntervalJoinOperator.BufferEntry<T> reuse) |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.createInstance() |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.deserialize(DataInputView source) |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.deserialize(IntervalJoinOperator.BufferEntry<T> reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<IntervalJoinOperator.BufferEntry<T>> |
IntervalJoinOperator.BufferEntrySerializer.duplicate() |
TypeSerializerSchemaCompatibility<IntervalJoinOperator.BufferEntry<T>> |
IntervalJoinOperator.BufferSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<IntervalJoinOperator.BufferEntry<T>> newSerializer)
Deprecated.
|
TypeSerializerSnapshot<IntervalJoinOperator.BufferEntry<T>> |
IntervalJoinOperator.BufferEntrySerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.copy(IntervalJoinOperator.BufferEntry<T> from) |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.copy(IntervalJoinOperator.BufferEntry<T> from,
IntervalJoinOperator.BufferEntry<T> reuse) |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.copy(IntervalJoinOperator.BufferEntry<T> from,
IntervalJoinOperator.BufferEntry<T> reuse) |
IntervalJoinOperator.BufferEntry<T> |
IntervalJoinOperator.BufferEntrySerializer.deserialize(IntervalJoinOperator.BufferEntry<T> reuse,
DataInputView source) |
void |
IntervalJoinOperator.BufferEntrySerializer.serialize(IntervalJoinOperator.BufferEntry<T> record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<IntervalJoinOperator.BufferEntry<T>> |
IntervalJoinOperator.BufferSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<IntervalJoinOperator.BufferEntry<T>> newSerializer)
Deprecated.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.