Uses of Class
org.apache.flink.streaming.api.utils.ByteArrayWrapper
-
Packages that use ByteArrayWrapper Package Description org.apache.flink.python.util org.apache.flink.streaming.api.runners.python.beam.state org.apache.flink.streaming.api.utils -
-
Uses of ByteArrayWrapper in org.apache.flink.python.util
Methods in org.apache.flink.python.util that return types with arguments of type ByteArrayWrapper Modifier and Type Method Description static List<org.apache.flink.api.common.state.MapStateDescriptor<ByteArrayWrapper,byte[]>>
PythonConfigUtil. convertStateNamesToStateDescriptors(String[] names)
-
Uses of ByteArrayWrapper in org.apache.flink.streaming.api.runners.python.beam.state
Methods in org.apache.flink.streaming.api.runners.python.beam.state that return types with arguments of type ByteArrayWrapper Modifier and Type Method Description org.apache.flink.api.common.state.MapState<ByteArrayWrapper,byte[]>
BeamKeyedStateStore. getMapState(org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest request)
org.apache.flink.api.common.state.MapState<ByteArrayWrapper,byte[]>
BeamOperatorStateStore. getMapState(org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest request)
Returns aBroadcastState
wrapped inMapState
interface.org.apache.flink.api.common.state.MapState<ByteArrayWrapper,byte[]>
BeamStateStore. getMapState(org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest request)
ParseBeamFnApi.StateRequest
and return the correspondingMapState
.Method parameters in org.apache.flink.streaming.api.runners.python.beam.state with type arguments of type ByteArrayWrapper Modifier and Type Method Description org.apache.beam.model.fnexecution.v1.BeamFnApi.StateResponse.Builder
BeamMapStateHandler. handleAppend(org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest request, org.apache.flink.api.common.state.MapState<ByteArrayWrapper,byte[]> mapState)
org.apache.beam.model.fnexecution.v1.BeamFnApi.StateResponse.Builder
BeamMapStateHandler. handleClear(org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest request, org.apache.flink.api.common.state.MapState<ByteArrayWrapper,byte[]> mapState)
org.apache.beam.model.fnexecution.v1.BeamFnApi.StateResponse.Builder
BeamMapStateHandler. handleGet(org.apache.beam.model.fnexecution.v1.BeamFnApi.StateRequest request, org.apache.flink.api.common.state.MapState<ByteArrayWrapper,byte[]> mapState)
-
Uses of ByteArrayWrapper in org.apache.flink.streaming.api.utils
Methods in org.apache.flink.streaming.api.utils that return ByteArrayWrapper Modifier and Type Method Description ByteArrayWrapper
ByteArrayWrapper. copy()
ByteArrayWrapper
ByteArrayWrapperSerializer. copy(ByteArrayWrapper from)
ByteArrayWrapper
ByteArrayWrapperSerializer. copy(ByteArrayWrapper from, ByteArrayWrapper reuse)
ByteArrayWrapper
ByteArrayWrapperSerializer. createInstance()
ByteArrayWrapper
ByteArrayWrapperSerializer. deserialize(org.apache.flink.core.memory.DataInputView source)
ByteArrayWrapper
ByteArrayWrapperSerializer. deserialize(ByteArrayWrapper reuse, org.apache.flink.core.memory.DataInputView source)
Methods in org.apache.flink.streaming.api.utils that return types with arguments of type ByteArrayWrapper Modifier and Type Method Description org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<ByteArrayWrapper>
ByteArrayWrapperSerializer. snapshotConfiguration()
Methods in org.apache.flink.streaming.api.utils with parameters of type ByteArrayWrapper Modifier and Type Method Description ByteArrayWrapper
ByteArrayWrapperSerializer. copy(ByteArrayWrapper from)
ByteArrayWrapper
ByteArrayWrapperSerializer. copy(ByteArrayWrapper from, ByteArrayWrapper reuse)
ByteArrayWrapper
ByteArrayWrapperSerializer. deserialize(ByteArrayWrapper reuse, org.apache.flink.core.memory.DataInputView source)
void
ByteArrayWrapperSerializer. serialize(ByteArrayWrapper record, org.apache.flink.core.memory.DataOutputView target)
-