Uses of Class
com.tangosol.util.Binary
Package
Description
The base package provides a number of classes to complement those in the java.lang package.
Low-level utilities for Coherence gRPC server and client implementation.
The Coherence gRPC server implementation.
Contains Federation conflict resolution interfaces.
Contains classes related to REST marshalling.
Contains packages and classes related to the Coherence REST API utilities.
Contains classes providing cache persistence of serialized objects.
Contains Sleepycat Berkeley DB BinaryStore implementation classes.
Contains classes related to J2SE 1.4 NIO functionality.
Contains classes related to POF serialization and deserialization.
Contains classes related to POF stream navigation and manipulation.
Contains classes providing various caching strategies.
Contains classes that providing topic entities for publish/subscribe messaging.
Contains classes and helpers for implementing various types of persistence.
Contains classes providing basic XML related functionality.
Contains various generic utilities.
-
Uses of Binary in com.oracle.coherence.common.base
Modifier and TypeMethodDescriptionstatic Binary
Randoms.getRandomBinary
(int cbMin, int cbMax) Generates a random-length Binary within the length bounds provided whose contents are random bytes.static Binary
Randoms.getRandomBinary
(int cbMin, int cbMax, byte... abHead) Generates a random-length Binary includingabHead
at the head of the Binary, in addition to random bytes within the length bounds provided. -
Uses of Binary in com.oracle.coherence.grpc
Modifier and TypeFieldDescriptionprotected final AsyncNamedCache
<Binary, Binary> CacheRequestHolder.f_asyncNamedCache
TheAsyncNamedCache
that the request executes against.protected final AsyncNamedCache
<Binary, Binary> CacheRequestHolder.f_asyncNamedCache
TheAsyncNamedCache
that the request executes against.RequestHolder.DownConverter.f_converter
RequestHolder.m_converterDown
RequestHolder.m_converterDown
CacheRequestHolder.m_converterKeyDown
CacheRequestHolder.m_converterKeyDown
RequestHolder.m_converterUp
RequestHolder.m_converterUp
Modifier and TypeMethodDescriptionRequestHolder.convertDown
(com.google.protobuf.ByteString bytes) Convert theByteString
data serialized in the request format to aBinary
serialized in the cache's serialization format.RequestHolder.convertDown
(Binary binary) RequestHolder.convertDown
(Supplier<com.google.protobuf.ByteString> supplier) Convert theByteString
data serialized in the request format to aBinary
serialized in the cache's serialization format.CacheRequestHolder.convertKeyDown
(com.google.protobuf.ByteString bytes) Convert theByteString
data serialized in the request format to aBinary
key serialized in the cache's serialization format.CacheRequestHolder.convertKeyDown
(Binary binary) static Binary
BinaryHelper.toBinary
(com.google.protobuf.ByteString bytes) Convert aByteString
to aBinary
.static Binary
BinaryHelper.toBinary
(com.google.protobuf.BytesValue bytes) Convert aBytesValue
to aBinary
.static Binary
BinaryHelper.toBinaryKey
(com.google.protobuf.ByteString bytes) static Binary
BinaryHelper.toBinaryKey
(com.google.protobuf.BytesValue bytes) static Binary
BinaryHelper.toBinaryKey
(Binary binary) Modifier and TypeMethodDescriptionCacheRequestHolder.binaryConsumer
(io.grpc.stub.StreamObserver<com.google.protobuf.BytesValue> observer) CacheRequestHolder.createConverterDown()
RequestHolder.createConverterDown()
RequestHolder.ensureConverterDown()
RequestHolder.ensureConverterDown()
CacheRequestHolder.ensureConverterKeyDown()
CacheRequestHolder.ensureConverterKeyDown()
RequestHolder.ensureConverterUp()
RequestHolder.ensureConverterUp()
CacheRequestHolder.entryConsumer
(io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) CacheRequestHolder.entryConsumer
(io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) CacheRequestHolder.getAsyncCache()
Obtain theAsyncNamedCache
that the request executes on.CacheRequestHolder.getAsyncCache()
Obtain theAsyncNamedCache
that the request executes on.CacheRequestHolder.getCache()
Obtain theNamedCache
that the request executes on.CacheRequestHolder.getCache()
Obtain theNamedCache
that the request executes on.Modifier and TypeMethodDescriptionRequestHolder.convertDown
(Binary binary) CacheRequestHolder.convertKeyDown
(Binary binary) <T> T
RequestHolder.deserialize
(Binary binary) Obtain the deserializedBinary
value using the cache's serializer.com.google.protobuf.BytesValue
RequestHolder.deserializeToBytesValue
(Binary binary) Convert theBinary
serialized in the cache's serialization format to aBytesValue
serialized in the request's serialization format.static <T> T
BinaryHelper.fromBinary
(Binary binary, Serializer serializer) Deserialize a serializedBinary
.<T> T
RequestHolder.fromBinary
(Binary binary) Obtain the value deserialized from the specifiedBinary
using the cache's serializer.static Binary
BinaryHelper.toBinaryKey
(Binary binary) static com.google.protobuf.ByteString
BinaryHelper.toByteString
(Binary binary) Convert aBinary
to aByteString
.com.google.protobuf.ByteString
RequestHolder.toByteString
(Binary binary) Convert theBinary
serialized in the cache's serialization format to aByteString
serialized in the request's serialization format.static com.google.protobuf.BytesValue
BinaryHelper.toBytesValue
(Binary binary) Convert aBinary
to aBytesValue
.com.google.protobuf.BytesValue
RequestHolder.toBytesValue
(Binary binary) Convert theBinary
serialized in the cache's serialization format to aBytesValue
serialized in the request's serialization format.com.oracle.coherence.grpc.Entry
com.oracle.coherence.grpc.OptionalValue
RequestHolder.toOptionalValue
(Binary binary) Modifier and TypeMethodDescriptioncom.oracle.coherence.grpc.EntryResult
RequestHolder.toEntryResult
(Map.Entry<Binary, Binary> entry) com.oracle.coherence.grpc.EntryResult
RequestHolder.toEntryResult
(Map.Entry<Binary, Binary> entry) ModifierConstructorDescriptionCacheRequestHolder
(Req request, AsyncNamedCache<Binary, Binary> cache, Supplier<NamedCache<?, ?>> cacheSupplier, String sFormat, Serializer serializer, Executor executor) Create aCacheRequestHolder
.CacheRequestHolder
(Req request, AsyncNamedCache<Binary, Binary> cache, Supplier<NamedCache<?, ?>> cacheSupplier, String sFormat, Serializer serializer, Executor executor) Create aCacheRequestHolder
.protected
DownConverter
(Serializer serializer, Converter<Object, Binary> converter) -
Uses of Binary in com.oracle.coherence.grpc.proxy
Modifier and TypeFieldDescriptionMapListenerProxy.KeyConverter.f_converter
Converter to handle the conversion casesMapListenerProxy.KeyConverter.f_holder
doesn't cover.Modifier and TypeMethodDescriptionprotected InvocableMap.EntryProcessor
<Binary, Binary, Binary> NamedCacheServiceImpl.castProcessor
(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected InvocableMap.EntryProcessor
<Binary, Binary, Binary> NamedCacheServiceImpl.castProcessor
(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected InvocableMap.EntryProcessor
<Binary, Binary, Binary> NamedCacheServiceImpl.castProcessor
(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected CompletionStage
<CacheRequestHolder<com.oracle.coherence.grpc.ContainsEntryRequest, Binary>> NamedCacheServiceImpl.containsEntry
(CacheRequestHolder<com.oracle.coherence.grpc.ContainsEntryRequest, Void> holder) Execute theContainsEntryRequest
request and return aCompletionStage
that will complete when theAsyncNamedCache
request completes and will contain aCacheRequestHolder
holding the result of the contains entry request as a serialized Boolean.protected CompletionStage
<List<Binary>> NamedCacheServiceImpl.convertKeys
(CacheRequestHolder<com.oracle.coherence.grpc.GetAllRequest, Void> holder) Convert the keys for aGetAllRequest
from the request's serialization format to the cache's serialization format.protected CompletionStage
<CacheRequestHolder<com.oracle.coherence.grpc.GetRequest, Binary>> NamedCacheServiceImpl.get
(CacheRequestHolder<com.oracle.coherence.grpc.GetRequest, Void> holder) Execute theGetRequest
request and return aCompletionStage
that will complete when theAsyncNamedCache
request completes and will contain aCacheRequestHolder
holding the result of theGetRequest
request as a serialized Boolean.protected CompletionStage
<AsyncNamedCache<Binary, Binary>> NamedCacheServiceImpl.getAsyncCache
(String scope, String cacheName) Obtain anAsyncNamedCache
.protected CompletionStage
<AsyncNamedCache<Binary, Binary>> NamedCacheServiceImpl.getAsyncCache
(String scope, String cacheName) Obtain anAsyncNamedCache
.protected NamedCache
<Binary, Binary> Obtain anNamedCache
.protected NamedCache
<Binary, Binary> Obtain anNamedCache
.protected NamedCache
<Binary, Binary> NamedCacheServiceImpl.getPassThroughCache
(String scope, String cacheName) Obtain anNamedCache
.protected NamedCache
<Binary, Binary> NamedCacheServiceImpl.getPassThroughCache
(String scope, String cacheName) Obtain anNamedCache
.protected CompletionStage
<CacheRequestHolder<com.oracle.coherence.grpc.InvokeRequest, Binary>> NamedCacheServiceImpl.invoke
(CacheRequestHolder<com.oracle.coherence.grpc.InvokeRequest, Void> holder) Execute theInvokeRequest
request and return aCompletionStage
that will complete when theAsyncNamedCache
request completes and will contain aCacheRequestHolder
holding the result of theInvokeRequest
request as a serialized Boolean.protected CompletableFuture
<Binary> NamedCacheServiceImpl.remove
(CacheRequestHolder<com.oracle.coherence.grpc.RemoveRequest, Void> holder) Execute aRemoveRequest
request.protected CompletableFuture
<Binary> NamedCacheServiceImpl.replace
(CacheRequestHolder<com.oracle.coherence.grpc.ReplaceRequest, Void> holder) Execute aReplaceRequest
request.protected CompletableFuture
<Binary> NamedCacheServiceImpl.replaceMapping
(CacheRequestHolder<com.oracle.coherence.grpc.ReplaceMappingRequest, Void> holder) Execute aReplaceMappingRequest
request.Modifier and TypeMethodDescriptionprotected com.google.protobuf.BoolValue
NamedCacheServiceImpl.toBoolValue
(Binary binary, Serializer serializer) Deserialize aBinary
to a boolean value.Modifier and TypeMethodDescriptionprotected InvocableMap.EntryProcessor
<Binary, Binary, Binary> NamedCacheServiceImpl.castProcessor
(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected InvocableMap.EntryProcessor
<Binary, Binary, Binary> NamedCacheServiceImpl.castProcessor
(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) static Void
ResponseHandlers.handleMapOfEntries
(RequestHolder<?, Map<Binary, Binary>> holder, Throwable err, io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver
.static Void
ResponseHandlers.handleMapOfEntries
(RequestHolder<?, Map<Binary, Binary>> holder, Throwable err, io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver
.static Void
ResponseHandlers.handleSetOfEntries
(RequestHolder<?, Set<Map.Entry<Binary, Binary>>> holder, Throwable err, io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) Handle the result of the asynchronous entry set request sending the results, or any errors to theStreamObserver
.static Void
ResponseHandlers.handleSetOfEntries
(RequestHolder<?, Set<Map.Entry<Binary, Binary>>> holder, Throwable err, io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) Handle the result of the asynchronous entry set request sending the results, or any errors to theStreamObserver
.static Void
ResponseHandlers.handleStream
(RequestHolder<?, ? extends Iterable<Binary>> holder, Throwable err, io.grpc.stub.StreamObserver<com.google.protobuf.BytesValue> observer) static void
ResponseHandlers.handleStreamOfEntries
(RequestHolder<?, ?> holder, Stream<Map.Entry<Binary, Binary>> entries, io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver
.static void
ResponseHandlers.handleStreamOfEntries
(RequestHolder<?, ?> holder, Stream<Map.Entry<Binary, Binary>> entries, io.grpc.stub.StreamObserver<com.oracle.coherence.grpc.Entry> observer) Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver
.protected void
MapListenerProxy.onFilterRequest
(com.oracle.coherence.grpc.MapListenerRequest request, MapTrigger<Binary, Binary> trigger) Invoked whenMapListenerRequest.RequestType
isKEY
.protected void
MapListenerProxy.onFilterRequest
(com.oracle.coherence.grpc.MapListenerRequest request, MapTrigger<Binary, Binary> trigger) Invoked whenMapListenerRequest.RequestType
isKEY
.protected CompletionStage
<com.google.protobuf.Empty> NamedCacheServiceImpl.partitionedPutAll
(CacheRequestHolder<com.oracle.coherence.grpc.PutAllRequest, Void> holder, Map<Binary, Binary> map) Perform aputAll
operation on a partitioned cache.protected CompletionStage
<com.google.protobuf.Empty> NamedCacheServiceImpl.partitionedPutAll
(CacheRequestHolder<com.oracle.coherence.grpc.PutAllRequest, Void> holder, Map<Binary, Binary> map) Perform aputAll
operation on a partitioned cache.protected CompletionStage
<com.google.protobuf.Empty> NamedCacheServiceImpl.plainPutAll
(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAll
operation on a partitioned cache.protected CompletionStage
<com.google.protobuf.Empty> NamedCacheServiceImpl.plainPutAll
(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAll
operation on a partitioned cache.protected CompletionStage
<com.google.protobuf.Empty> NamedCacheServiceImpl.plainPutAll
(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAll
operation on a partitioned cache.protected CompletionStage
<com.google.protobuf.Empty> NamedCacheServiceImpl.plainPutAll
(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAll
operation on a partitioned cache. -
Uses of Binary in com.tangosol.coherence.federation
Modifier and TypeMethodDescriptionChangeRecord.getBinaryChangeRecord()
ChangeRecord.getBinaryChangeRecord()
-
Uses of Binary in com.tangosol.coherence.rest.io
Modifier and TypeMethodDescriptionBinaryMarshaller.unmarshal
(InputStream in, jakarta.ws.rs.core.MediaType mediaType) Modifier and TypeMethodDescriptionvoid
BinaryMarshaller.marshal
(Binary value, OutputStream out, jakarta.ws.rs.core.MultivaluedMap<String, Object> httpHeaders) -
Uses of Binary in com.tangosol.coherence.rest.util
ModifierConstructorDescriptionStaticContent
(Binary binContent, String sMediaType) Construct StaticContent instance. -
Uses of Binary in com.tangosol.io
Modifier and TypeFieldDescriptionprotected static Binary
DecorationOnlyDeltaCompressor.BIN_DECO_ONLY
A place-holder Binary value used by the compressor to indicate a decoration-only update.protected static final Binary
AsyncBinaryStore.DELETED
A special token that is used to signify a queued erase operation.protected static final Binary
BinaryDeltaCompressor.DELTA_TRUNCATE
A delta value that indicates an empty new value.protected Binary
SimpleEvolvable.m_binFutureData
Future data.static final Binary
AbstractReadBuffer.NO_BINARY
An empty Binary object.static final Binary
AbstractWriteBuffer.NO_BINARY
An empty Binary object.protected static final Binary
BinaryDeltaCompressor.NO_BINARY
An empty Binary object.Modifier and TypeMethodDescriptionAbstractEvolvable.getFutureData()
Return all the unknown remainder of the data stream from which this object was deserialized.Evolvable.getFutureData()
Return all the unknown remainder of the data stream from which this object was deserialized.SimpleEvolvable.getFutureData()
Return all the unknown remainder of the data stream from which this object was deserialized.abstract Binary
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.AbstractByteArrayReadBuffer.toBinary()
Return a new Binary object that holds the complete contents of this ReadBuffer.AbstractByteArrayReadBuffer.toBinary
(int of, int cb) Return a Binary object that holds the specified portion of this ReadBuffer.AbstractReadBuffer.toBinary()
Return a new Binary object that holds the complete contents of this ReadBuffer.AbstractReadBuffer.toBinary
(int of, int cb) Return a Binary object that holds the specified portion of this ReadBuffer.AbstractWriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.ByteArrayWriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.DelegatingWriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.MultiBufferReadBuffer.toBinary
(int of, int cb) Return a Binary object that holds the specified portion of this ReadBuffer.MultiBufferWriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.ReadBuffer.toBinary()
Return a new Binary object that holds the complete contents of this ReadBuffer.ReadBuffer.toBinary
(int of, int cb) Return a Binary object that holds the specified portion of this ReadBuffer.WriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.Modifier and TypeMethodDescriptionboolean
BinaryStore.KeySetAware.containsKey
(Binary binKey) Return true iff this BinaryStore contains a mapping for the specified key.void
Remove the specified key from the underlying store if present.void
Remove the specified key from the underlying store if present.void
Remove the specified key from the underlying store if present.abstract Binary
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.protected void
AsyncBinaryStore.QueueDaemon.processPending
(Binary binKey, Binary binValue) Store the specified value under the specific key in the underlying store, or if the value isAsyncBinaryStore.DELETED
then erase the value from the underlying store.void
AbstractEvolvable.setFutureData
(Binary binFuture) Store the unknown remainder of the data stream from which this object is being deserialized.void
Evolvable.setFutureData
(Binary binFuture) Store the unknown remainder of the data stream from which this object is being deserialized.void
SimpleEvolvable.setFutureData
(Binary binFutureData) Store the unknown remainder of the data stream from which this object is being deserialized.void
Store the specified value under the specific key in the underlying store.void
Store the specified value under the specific key in the underlying store.void
Store the specified value under the specific key in the underlying store. -
Uses of Binary in com.tangosol.io.bdb
Modifier and TypeMethodDescriptionReturn the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Modifier and TypeMethodDescriptionvoid
Remove the specified key from the underlying store if present.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.void
Store the specified value under the specific key in the underlying store. -
Uses of Binary in com.tangosol.io.nio
Modifier and TypeMethodDescriptionprotected static Binary
Internal debugging support: Turn a String into a Binary.BinaryMap.Block.getKey()
Get the Entry key in the block, lazy loading it if necessary.BinaryMap.Block.getValue()
Get the Entry value in the block, lazy loading it if necessary.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.ByteBufferReadBuffer.toBinary
(int of, int cb) Return a Binary object that holds the specified portion of this ReadBuffer.ByteBufferWriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.Modifier and TypeMethodDescriptionvoid
Remove the specified key from the underlying store if present.protected BinaryMap.Block
BinaryMap.findEntryBlock
(Binary binKey) Find the Entry block with the specified key.protected BinaryMap.Entry
BinaryMap.instantiateEntry
(Binary binKey, Binary binValue) Factory pattern: Instantiate an Entry object.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.void
Update the Entry key in the block.void
Update the Entry value in the block.void
Store the specified value under the specific key in the underlying store. -
Uses of Binary in com.tangosol.io.pof
Modifier and TypeFieldDescriptionstatic final Binary
PofHelper.BINARY_EMPTY
An empty Binary value.Modifier and TypeMethodDescriptionRawQuad.getBits()
Obtain the raw binary form of the 128-bit float.PofDeltaCompressor.ChangeTracker.getDelta()
Obtain the final delta result as a Binary value.PofBufferReader.readBinary
(int iProp) Read a Binary from the POF stream.protected static Binary
PofBufferReader.readBinary
(ReadBuffer.BufferInput in) Read a Binary object from the specified BufferInput in an optimal way, depending on the existence of an enclosing ReadBuffer.PofReader.readBinary
(int iProp) Read a Binary from the POF stream.PofBufferReader.readRemainder()
Read all remaining indexed properties of the current user type from the POF stream.PofBufferReader.UserTypeReader.readRemainder()
Read all remaining indexed properties of the current user type from the POF stream.PofReader.readRemainder()
Read all remaining indexed properties of the current user type from the POF stream.Modifier and TypeMethodDescriptionvoid
AbstractPofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.void
DuplexingPofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.void
LoggingPofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.void
PofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.void
ValidatingPofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.void
WritingPofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.void
PofBufferWriter.writeBinary
(int iProp, Binary bin) Write aBinary
property to the POF stream.void
PofWriter.writeBinary
(int iProp, Binary bin) Write aBinary
property to the POF stream.void
PofBufferWriter.UserTypeWriter.writeRemainder
(Binary binProps) Write the remaining properties to the POF stream, terminating the writing of the current user type.void
PofBufferWriter.writeRemainder
(Binary binProps) Write the remaining properties to the POF stream, terminating the writing of the current user type.void
PofWriter.writeRemainder
(Binary binProps) Write the remaining properties to the POF stream, terminating the writing of the current user type. -
Uses of Binary in com.tangosol.io.pof.reflect
Modifier and TypeMethodDescriptionAbstractPofValue.applyChanges()
Apply all the changes that were made to this value and return a binary representation of the new value.PofValue.applyChanges()
Apply all the changes that were made to this value and return a binary representation of the new value. -
Uses of Binary in com.tangosol.net.cache
Modifier and TypeFieldDescriptionprotected static final Binary
ReadWriteBackingMap.BIN_STORE_PENDING
The binary form of the decoration indicating that the CacheStore on the primary member has not yet written the value.protected Binary
BackingMapBinaryEntry.m_binKey
The Binary key.protected Binary
BackingMapBinaryEntry.m_binValue
The Binary value.protected Binary
BackingMapBinaryEntry.m_binValueOrig
The original Binary value.protected static final Binary
ReadWriteBackingMap.REMOVED
Marker object used byReadWriteBackingMap.Entry
to indicateremove
was called on the Entry.Modifier and TypeMethodDescriptionBackingMapBinaryEntry.getBinaryKey()
Return a raw binary key for this entry.BackingMapBinaryEntry.getBinaryValue()
Return a raw binary value for this entry.ReadWriteBackingMap.Entry.getChangedBinaryValue()
Return the Binary value changed by the BinaryEntryStore.BackingMapBinaryEntry.getOriginalBinaryValue()
Return a raw original binary value for this entry.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.protected Binary
Translate the passed Object object into an Binary object.protected Binary
Translate the passed Object object into an Binary object.protected Binary
Translate the passed Object object into an Binary object.protected Binary
ContinuousQueryCache.toInternal
(Object oValue) Serialize the provided value into aBinary
.Modifier and TypeMethodDescriptionboolean
ReadWriteBackingMap.WriteQueue.accelerateEntryRipe
(Binary binKey) Move the ripe time for the queued entry up to accelerate the store operation.void
Remove the specified key from the underlying store if present.void
Remove the specified key from the underlying store if present.void
Remove the specified key from the underlying store if present.protected Object
BinaryStoreCacheStore.fromBinary
(Binary bin) Translate the passed Binary object into an Object object.protected Object
SerializationMap.fromBinary
(Binary bin) Translate the passed Binary object into an Object object.protected Object
SimpleSerializationMap.fromBinary
(Binary bin) Translate the passed Binary object into an Object object.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.protected void
SerializationCache.registerKey
(Object oKey, Binary binKey, Binary binValue) Register a new key for the SerializationMap.protected void
SerializationCache.registerKey
(Object oKey, Binary binKey, Binary binValue, int cMillis) Register a new key for the SerializationMap.protected void
SerializationMap.registerKey
(Object oKey, Binary binKey, Binary binValue) Register a new key for the SerializationMap.void
Store the specified value under the specific key in the underlying store.void
Store the specified value under the specific key in the underlying store.void
Store the specified value under the specific key in the underlying store.void
BackingMapBinaryEntry.updateBinaryValue
(Binary binValue) Update the binary value for this entry.void
BackingMapBinaryEntry.updateBinaryValue
(Binary binValue, boolean fSynthetic) Update the binary value for this entry.void
ReadWriteBackingMap.Entry.updateBinaryValue
(Binary binValue) Update the binary value for this entry.ModifierConstructorDescriptionBackingMapBinaryEntry
(Binary binKey, Binary binValue, Binary binValueOrig, long cDelay, BackingMapManagerContext ctx) Construct a BackingMapBinaryEntry with the specified binary key, values and BackingMapManagerContext.BackingMapBinaryEntry
(Binary binKey, Binary binValue, Binary binValueOrig, BackingMapManagerContext ctx) Construct a BackingMapBinaryEntry with the specified binary key, values and BackingMapManagerContext.Entry
(Binary binKey, Binary binValue, Binary binValueOrig, long cExpiry, BackingMapManagerContext ctx) Construct an Entry with just a key. -
Uses of Binary in com.tangosol.net.topic
Modifier and TypeMethodDescriptionSubscriber.Element.getBinaryValue()
Returns the element's value in serialized form.TopicPublisherException.getBinaryValue()
Returns the value that failed to be published in serializedBinary
format.Modifier and TypeMethodDescriptionstatic BiFunction
<Throwable, Binary, Throwable> TopicPublisherException.createFactory
(Serializer serializer) Create a factory function that creates aTopicPublisherException
.static BiFunction
<Throwable, Binary, Throwable> TopicPublisherException.createFactory
(Serializer serializer, String sReason) Create a factory function that creates aTopicPublisherException
.Modifier and TypeMethodDescriptionint
BinaryElementCalculator.calculateUnits
(Binary binElement) int
FixedElementCalculator.calculateUnits
(Binary binElement) int
NamedTopic.ElementCalculator.calculateUnits
(Binary binElement) Calculate cost for the specified element.ModifierConstructorDescriptionTopicPublisherException
(String sMessage, Binary binValue, Serializer serializer) Create aTopicPublisherException
.TopicPublisherException
(String sMessage, Throwable cause, Binary binValue, Serializer serializer) Create aTopicPublisherException
.TopicPublisherException
(Throwable cause, Binary binValue, Serializer serializer) Create aTopicPublisherException
. -
Uses of Binary in com.tangosol.persistence
Modifier and TypeMethodDescriptionstatic Binary
CachePersistenceHelper.readQuorumRaw
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store) Read the membership information in Binary format from the "META" extent.static Binary
CachePersistenceHelper.writeQuorum
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, PartitionedService service) Write the current membership information to the "META" extent.Modifier and TypeMethodDescriptionprotected static ReadBuffer
CachePersistenceHelper.createIndexRegistrationKey
(long lCacheId, Binary binExtractor) Create a key representing an index registration.protected static ReadBuffer
CachePersistenceHelper.createListenerRegistrationKey
(long lMemberId, long lCacheId, Binary binKey) Create a key representing a cache listener registration.protected static ReadBuffer
CachePersistenceHelper.createLockRegistrationKey
(long lHolderId, long lHolderThreadId, long lCacheId, Binary binKey) Create a key representing a cache entry lock.protected static ReadBuffer
CachePersistenceHelper.createTriggerRegistrationKey
(long lCacheId, Binary binTrigger) Create a key representing an trigger registration.static void
CachePersistenceHelper.registerIndex
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binExtractor, Binary binComparator, Object oToken) Store the index registration in the specified persistent store.static void
CachePersistenceHelper.registerListener
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binKey, long lListenerId, boolean fLite, Object oToken) Store the listener registration in the specified persistent store.static void
CachePersistenceHelper.registerLock
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binKey, long lHolderId, long lHolderThreadId, Object oToken) Store the cache entry lock in the specified persistent store.static void
CachePersistenceHelper.registerTrigger
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binTrigger, Object oToken) Store the trigger registration in the specified persistent store.static void
CachePersistenceHelper.unregisterIndex
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binExtractor, Object oToken) Clear the index registration from the specified persistent store.static void
CachePersistenceHelper.unregisterListener
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binKey, long lListenerId, Object oToken) Clear the listener registration from the specified persistent store.static void
CachePersistenceHelper.unregisterLock
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binKey, long lHolderId, long lHolderThreadId, Object oToken) Clear the cache entry lock from the specified persistent store.static void
CachePersistenceHelper.unregisterTrigger
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binTrigger, Object oToken) Clear the trigger registration from the specified persistent store.boolean
AbstractPersistenceTools.StatsVisitor.visitCacheEntry
(long lOldCacheId, Binary binKey, Binary binValue) boolean
CachePersistenceHelper.Visitor.visitCacheEntry
(long lOldCacheId, Binary binKey, Binary binValue) Apply the visitor to the specified cache entry (key-value pair).boolean
AbstractPersistenceTools.StatsVisitor.visitIndex
(long lOldCacheId, Binary binExtractor, Binary binComparator) boolean
CachePersistenceHelper.Visitor.visitIndex
(long lOldCacheId, Binary binExtractor, Binary binComparator) Apply the visitor to the specified cache index.boolean
AbstractPersistenceTools.StatsVisitor.visitListener
(long lOldCacheId, Binary binKey, long lListenerId, boolean fLite) boolean
CachePersistenceHelper.Visitor.visitListener
(long lOldCacheId, Binary binKey, long lListenerId, boolean fLite) Apply the visitor to the specified cache entry listener.boolean
AbstractPersistenceTools.StatsVisitor.visitLock
(long lOldCacheId, Binary binKey, long lHolderId, long lHolderThreadId) boolean
CachePersistenceHelper.Visitor.visitLock
(long lOldCacheId, Binary binKey, long lHolderId, long lHolderThreadId) Apply the visitor to the specified cache entry lock.boolean
AbstractPersistenceTools.StatsVisitor.visitTrigger
(long lOldCacheId, Binary binTrigger) boolean
CachePersistenceHelper.Visitor.visitTrigger
(long lOldCacheId, Binary binTrigger) Apply the visitor to the specified trigger.static void
CachePersistenceHelper.writeQuorumRaw
(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, Binary binInfo) Write the current membership information in raw format to the "META" extent. -
Uses of Binary in com.tangosol.run.xml
Modifier and TypeMethodDescriptionSimpleValue.getBinary()
Get the value as binary.Get the value as binary.XmlValue.getBinary()
Get the value as binary.Get the value as binary.Modifier and TypeMethodDescriptionGet the value as binary.Get the value as binary.void
Set the binary value.void
Set the binary value. -
Uses of Binary in com.tangosol.util
Modifier and TypeFieldDescriptionstatic final Binary
Binary.EMPTY
An empty Binary.static final Binary[]
ExternalizableHelper.EMPTY_BINARY_ARRAY
An empty array of Binary objects.static final Binary
Binary.FALSE
A Binary representation ofBoolean.FALSE
value.static final Binary
Binary.TRUE
A Binary representation ofBoolean.TRUE
value.Modifier and TypeMethodDescriptionstatic Binary
ExternalizableHelper.asBinary
(ReadBuffer buf) Return a Binary representing the contents of the specified ReadBuffer, or null if the buffer is null.Concatenate the passed Binary onto this Binary.static Binary
Decorate the passed value with the specified decoration and return the resulting Binary.static Binary
Deprecated.as of Coherence 3.7.2BinaryEntry.getBinaryKey()
Return a raw binary key for this entry.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry.getBinaryKey()
Return a raw binary key for this entry.InvocableMapHelper.RoutingBinaryEntry.getBinaryKey()
Return a raw binary key for this entry.BinaryEntry.getBinaryValue()
Return a raw binary value for this entry.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry.getBinaryValue()
Return a raw binary value for this entry.InvocableMapHelper.RoutingBinaryEntry.getBinaryValue()
Return an OriginalBinaryValue from the underlying entry.static Binary
ExternalizableHelper.getDecoration
(Binary bin, int nId) Deprecated.as of Coherence 3.7.2BinaryEntry.getOriginalBinaryValue()
Return a raw original binary value for this entry.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry.getOriginalBinaryValue()
Return a raw original binary value for this entry.InvocableMapHelper.RoutingBinaryEntry.getOriginalBinaryValue()
static Binary
Base.getRandomBinary
(int cbMin, int cbMax) Generates a random-length Binary within the length bounds provided whose contents are random bytes.static Binary
Base.getRandomBinary
(int cbMin, int cbMax, byte... abHead) Generates a random-length Binary includingabHead
at the head of the Binary, in addition to random bytes within the length bounds provided.static Binary
ExternalizableHelper.getUndecorated
(Binary bin) Deprecated.as of Coherence 3.7.2static Binary
Join an array of Binaries into a single Binary.Unsafe.newBinary
(byte[] ab, int of, int cb) Return a newBinary
instance backed by the specified byte[] beginning at the specified offset and of the specified length.static Binary
Binary.readBinary
(DataInput input) Read a Binary from the specified DataInput.static Binary
Binary.readBinary
(DataInputStream in) Read a Binary from the specified DataInputStream.static Binary
Binary.readBinary
(File file) Read a Binary from the specified File.static Binary
Binary.readBinary
(InputStream in) Read a Binary from the specified InputStream.static Binary
Binary.readBinary
(InputStream in, int cb) Read a Binary from the specified InputStream.static Binary
Binary.readBinary
(URL url) Read a Binary from the specified URL.static Binary
Binary.readBinary
(FileChannel channel, long of, int cb, byte[] ab2) Read a Binary of the specified length at the specified offset from the specified FileChannel.static Binary
ExternalizableHelper.removeIntDecoration
(Binary bin) Deprecated.as of Coherence 3.7.2Binary.replace
(byte bOld, byte bNew) Replace all occurrences of one specified byte with another in this Binary object.Replace all occurrences of one specified Binary with another in this Binary object.Binary.replaceRegion
(int of, int cb, Binary binNew) Replace a region within this Binary with another Binary.Binary.reverse()
Reverse this Binary object's byte sequence such that the byte at offset zero of this sequence occurs at offset length()-1 in the resulting sequence, the byte at offset one of this sequence occurs at offset length()-2 in the resulting sequence, and so on.Binary[]
Binary.split
(int nSize) Split a Binary into an array of Binaries each of which does not exceed the specified size.AbstractByteSequence.toBinary()
Returns a Binary object that holds the contents of this ByteSequence.Binary.toBinary()
Return a new Binary object that holds the complete contents of this ReadBuffer.Binary.toBinary
(int of, int cb) Return a Binary object that holds the specified portion of this ReadBuffer.BinaryWriteBuffer.toBinary()
Returns a new Binary object that holds the complete contents of this WriteBuffer.ByteSequence.toBinary()
Returns a Binary object that holds the contents of this ByteSequence.static Binary
Write an object into a Binary object.static Binary
ExternalizableHelper.toBinary
(Object o, Serializer serializer) Write an object into a Binary object using the specified Serializer.static Binary
ExternalizableHelper.toBinary
(Object o, Serializer serializer, WriteBuffer buf) Write an object into a Binary object using the specified Serializer.static Binary
ExternalizableHelper.toLiteBinary
(ExternalizableLite o) Write an ExternalizableLite object into a Binary object.static Binary
ExternalizableHelper.undecorate
(Binary bin, int nId) Deprecated.as of Coherence 3.7.2Modifier and TypeMethodDescriptionConcatenate the passed Binary onto this Binary.static Binary
Decorate the passed value with the specified decoration and return the resulting Binary.static Binary
Deprecated.as of Coherence 3.7.2boolean
Tests if this Binary object ends with the specified suffix.static <T> T
ExternalizableHelper.fromBinary
(Binary bin) Read an object from a Binary object.static <T> T
ExternalizableHelper.fromBinary
(Binary bin, Serializer serializer) Read an object from a Binary object using the specified Serializer.static <T> T
ExternalizableHelper.fromBinary
(Binary bin, Serializer serializer, Remote.Function<ReadBuffer.BufferInput, ReadBuffer.BufferInput> supplier) Read an object from a Binary object using the specified Serializer.static <T> T
ExternalizableHelper.fromBinary
(Binary bin, Serializer serializer, Remote.Function<ReadBuffer.BufferInput, ReadBuffer.BufferInput> supplier, Class<T> clazz) Read an object from a Binary object using the specified Serializer and expected class.static <T> T
ExternalizableHelper.fromBinary
(Binary bin, Serializer serializer, Class<T> clazz) Read an object from a Binary object using the specified Serializer and expected class.static <T> T
ExternalizableHelper.fromBinary
(Binary bin, ClassLoader loader) Read an object from a Binary object.int
Unsafe.getArrayOffset
(Binary bin) Return the offset into theunderlying byte array
for the specified Binary.byte[]
Unsafe.getByteArray
(Binary bin) Return the underlying byte[] for the specified Binary.static Binary
ExternalizableHelper.getDecoration
(Binary bin, int nId) Deprecated.as of Coherence 3.7.2static Binary
ExternalizableHelper.getUndecorated
(Binary bin) Deprecated.as of Coherence 3.7.2int
Returns the offset within this Binary object of the first occurrence of the specified Binary.int
Returns the offset within this Binary object of the first occurrence of the specified Binary, starting the search at the specified offset.static Binary
Join an array of Binaries into a single Binary.int
Binary.lastIndexOf
(Binary bin) Returns the offset within this Binary object of the last occurrence of the specified Binary.int
Binary.lastIndexOf
(Binary bin, int ofFrom) Returns the offset within this Binary object of the last occurrence of the specified Binary, starting the search at the specified offset.void
NullImplementation.NullPofHandler.onOctetString
(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.boolean
Binary.regionMatches
(int ofThis, Binary that, int ofThat, int cb) Tests if two Binary regions are equal.static Binary
ExternalizableHelper.removeIntDecoration
(Binary bin) Deprecated.as of Coherence 3.7.2Replace all occurrences of one specified Binary with another in this Binary object.Binary.replaceRegion
(int of, int cb, Binary binNew) Replace a region within this Binary with another Binary.boolean
Binary.startsWith
(Binary bin) Tests if this Binary object starts with the specified prefix.boolean
Binary.startsWith
(Binary bin, int ofFrom) Tests if this Binary object starts with the specified prefix beginning a specified offset.static Binary
ExternalizableHelper.undecorate
(Binary bin, int nId) Deprecated.as of Coherence 3.7.2void
BinaryEntry.updateBinaryValue
(Binary binValue) Update the binary value for this entry.void
BinaryEntry.updateBinaryValue
(Binary binValue, boolean fSynthetic) Update the binary value for this entry.void
ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry.updateBinaryValue
(Binary binValue) Update the binary value for this entry.void
ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry.updateBinaryValue
(Binary binValue, boolean fSynthetic) Update the binary value for this entry.void
InvocableMapHelper.RoutingBinaryEntry.updateBinaryValue
(Binary binValue) void
InvocableMapHelper.RoutingBinaryEntry.updateBinaryValue
(Binary binValue, boolean fSynthetic)