Uses of Class
com.tangosol.util.Binary
Packages that use 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 Netty based 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 basic cluster interfaces and factories.
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
Methods in com.oracle.coherence.common.base that return BinaryModifier and TypeMethodDescriptionstatic BinaryRandoms.getRandomBinary(int cbMin, int cbMax) Generates a random-length Binary within the length bounds provided whose contents are random bytes.static BinaryRandoms.getRandomBinary(int cbMin, int cbMax, byte... abHead) Generates a random-length Binary includingabHeadat the head of the Binary, in addition to random bytes within the length bounds provided. - 
Uses of Binary in com.oracle.coherence.grpc
Fields in com.oracle.coherence.grpc with type parameters of type BinaryModifier and TypeFieldDescriptionprotected final AsyncNamedCache<Binary, Binary> CacheRequestHolder.f_asyncNamedCacheTheAsyncNamedCachethat the request executes against.protected final AsyncNamedCache<Binary, Binary> CacheRequestHolder.f_asyncNamedCacheTheAsyncNamedCachethat the request executes against.RequestHolder.DownConverter.f_converterRequestHolder.m_converterDownRequestHolder.m_converterDownCacheRequestHolder.m_converterKeyDownCacheRequestHolder.m_converterKeyDownRequestHolder.m_converterUpRequestHolder.m_converterUpMethods in com.oracle.coherence.grpc that return BinaryModifier and TypeMethodDescriptionRequestHolder.convertDown(com.google.protobuf.ByteString bytes) Convert theByteStringdata serialized in the request format to aBinaryserialized in the cache's serialization format.RequestHolder.convertDown(Binary binary) RequestHolder.convertDown(Supplier<com.google.protobuf.ByteString> supplier) Convert theByteStringdata serialized in the request format to aBinaryserialized in the cache's serialization format.CacheRequestHolder.convertKeyDown(com.google.protobuf.ByteString bytes) Convert theByteStringdata serialized in the request format to aBinarykey serialized in the cache's serialization format.CacheRequestHolder.convertKeyDown(Binary binary) static BinaryBinaryHelper.toBinary(com.google.protobuf.ByteString bytes) Convert aByteStringto aBinary.static BinaryBinaryHelper.toBinary(com.google.protobuf.BytesValue bytes) Convert aBytesValueto aBinary.Methods in com.oracle.coherence.grpc that return types with arguments of type BinaryModifier 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 theAsyncNamedCachethat the request executes on.CacheRequestHolder.getAsyncCache()Obtain theAsyncNamedCachethat the request executes on.CacheRequestHolder.getCache()Obtain theNamedCachethat the request executes on.CacheRequestHolder.getCache()Obtain theNamedCachethat the request executes on.Methods in com.oracle.coherence.grpc with parameters of type BinaryModifier and TypeMethodDescriptionRequestHolder.convertDown(Binary binary) CacheRequestHolder.convertKeyDown(Binary binary) <T> TRequestHolder.deserialize(Binary binary) Obtain the deserializedBinaryvalue using the cache's serializer.com.google.protobuf.BytesValueRequestHolder.deserializeToBytesValue(Binary binary) Convert theBinaryserialized in the cache's serialization format to aBytesValueserialized in the request's serialization format.static <T> TBinaryHelper.fromBinary(Binary binary, Serializer serializer) Deserialize a serializedBinary.<T> TRequestHolder.fromBinary(Binary binary) Obtain the value deserialized from the specifiedBinaryusing the cache's serializer.static com.google.protobuf.ByteStringBinaryHelper.toByteString(Binary binary) Convert aBinaryto aByteString.com.google.protobuf.ByteStringRequestHolder.toByteString(Binary binary) Convert theBinaryserialized in the cache's serialization format to aByteStringserialized in the request's serialization format.static com.google.protobuf.BytesValueBinaryHelper.toBytesValue(Binary binary) Convert aBinaryto aBytesValue.com.google.protobuf.BytesValueRequestHolder.toBytesValue(Binary binary) Convert theBinaryserialized in the cache's serialization format to aBytesValueserialized in the request's serialization format.com.oracle.coherence.grpc.Entrystatic com.google.protobuf.ByteStringBinaryHelper.toKeyByteString(Binary bin, Object obj, Serializer serializer) com.oracle.coherence.grpc.OptionalValueRequestHolder.toOptionalValue(Binary binary) Method parameters in com.oracle.coherence.grpc with type arguments of type BinaryModifier and TypeMethodDescriptioncom.oracle.coherence.grpc.EntryResultRequestHolder.toEntryResult(Map.Entry<Binary, Binary> entry) com.oracle.coherence.grpc.EntryResultRequestHolder.toEntryResult(Map.Entry<Binary, Binary> entry) Constructor parameters in com.oracle.coherence.grpc with type arguments of type BinaryModifierConstructorDescriptionCacheRequestHolder(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.protectedDownConverter(Serializer serializer, Converter<Object, Binary> converter)  - 
Uses of Binary in com.oracle.coherence.grpc.proxy
Methods in com.oracle.coherence.grpc.proxy that return types with arguments of type BinaryModifier and TypeMethodDescriptionprotected CompletionStage<CacheRequestHolder<com.oracle.coherence.grpc.ContainsEntryRequest, Binary>> NettyNamedCacheService.containsEntry(CacheRequestHolder<com.oracle.coherence.grpc.ContainsEntryRequest, Void> holder) Execute theContainsEntryRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of the contains entry request as a serialized Boolean.protected CompletionStage<List<Binary>> NettyNamedCacheService.convertKeys(CacheRequestHolder<com.oracle.coherence.grpc.GetAllRequest, Void> holder) Convert the keys for aGetAllRequestfrom the request's serialization format to the cache's serialization format.protected CompletionStage<CacheRequestHolder<com.oracle.coherence.grpc.GetRequest, Binary>> NettyNamedCacheService.get(CacheRequestHolder<com.oracle.coherence.grpc.GetRequest, Void> holder) Execute theGetRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of theGetRequestrequest as a serialized Boolean.protected CompletionStage<CacheRequestHolder<com.oracle.coherence.grpc.InvokeRequest, Binary>> NettyNamedCacheService.invoke(CacheRequestHolder<com.oracle.coherence.grpc.InvokeRequest, Void> holder) Execute theInvokeRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of theInvokeRequestrequest as a serialized Boolean.protected CompletableFuture<Binary> NettyNamedCacheService.remove(CacheRequestHolder<com.oracle.coherence.grpc.RemoveRequest, Void> holder) Execute aRemoveRequestrequest.protected CompletableFuture<Binary> NettyNamedCacheService.replace(CacheRequestHolder<com.oracle.coherence.grpc.ReplaceRequest, Void> holder) Execute aReplaceRequestrequest.protected CompletableFuture<Binary> NettyNamedCacheService.replaceMapping(CacheRequestHolder<com.oracle.coherence.grpc.ReplaceMappingRequest, Void> holder) Execute aReplaceMappingRequestrequest. - 
Uses of Binary in com.oracle.coherence.grpc.proxy.common
Fields in com.oracle.coherence.grpc.proxy.common with type parameters of type BinaryModifier and TypeFieldDescriptionMapListenerProxy.KeyConverter.f_converterConverter to handle the conversion casesMapListenerProxy.KeyConverter.f_holderdoesn't cover.Methods in com.oracle.coherence.grpc.proxy.common that return BinaryMethods in com.oracle.coherence.grpc.proxy.common that return types with arguments of type BinaryModifier and TypeMethodDescriptionprotected InvocableMap.EntryProcessor<Binary, Binary, Binary> BaseNamedCacheServiceImpl.castProcessor(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected InvocableMap.EntryProcessor<Binary, Binary, Binary> BaseNamedCacheServiceImpl.castProcessor(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected InvocableMap.EntryProcessor<Binary, Binary, Binary> BaseNamedCacheServiceImpl.castProcessor(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) BaseNamedCacheServiceImpl.convertKeysToBinary(CacheRequestHolder<com.oracle.coherence.grpc.GetAllRequest, Void> holder) Convert the keys for aGetAllRequestfrom the request's serialization format to the cache's serialization format.protected CompletionStage<AsyncNamedCache<Binary, Binary>> BaseNamedCacheServiceImpl.getAsyncCache(String scope, String cacheName) Obtain anAsyncNamedCache.protected CompletionStage<AsyncNamedCache<Binary, Binary>> BaseNamedCacheServiceImpl.getAsyncCache(String scope, String cacheName) Obtain anAsyncNamedCache.protected NamedCache<Binary, Binary> Obtain anNamedCache.protected NamedCache<Binary, Binary> Obtain anNamedCache.protected NamedCache<Binary, Binary> BaseNamedCacheServiceImpl.getPassThroughCache(String scope, String cacheName) Obtain anNamedCache.protected NamedCache<Binary, Binary> BaseNamedCacheServiceImpl.getPassThroughCache(String scope, String cacheName) Obtain anNamedCache.Methods in com.oracle.coherence.grpc.proxy.common with parameters of type BinaryModifier and TypeMethodDescriptionprotected com.google.protobuf.BoolValueBaseNamedCacheServiceImpl.toBoolValue(Binary binary, Serializer serializer) Deserialize aBinaryto a boolean value.Method parameters in com.oracle.coherence.grpc.proxy.common with type arguments of type BinaryModifier and TypeMethodDescriptionprotected InvocableMap.EntryProcessor<Binary, Binary, Binary> BaseNamedCacheServiceImpl.castProcessor(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) protected InvocableMap.EntryProcessor<Binary, Binary, Binary> BaseNamedCacheServiceImpl.castProcessor(InvocableMap.EntryProcessor<Binary, Binary, ?> ep) static VoidResponseHandlers.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 VoidResponseHandlers.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 VoidResponseHandlers.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 VoidResponseHandlers.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 VoidResponseHandlers.handleStream(RequestHolder<?, ? extends Iterable<Binary>> holder, Throwable err, io.grpc.stub.StreamObserver<com.google.protobuf.BytesValue> observer) static voidResponseHandlers.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 voidResponseHandlers.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 voidMapListenerProxy.onFilterRequest(com.oracle.coherence.grpc.MapListenerRequest request, MapTrigger<Binary, Binary> trigger) Invoked whenMapListenerRequest.RequestTypeisKEY.protected voidMapListenerProxy.onFilterRequest(com.oracle.coherence.grpc.MapListenerRequest request, MapTrigger<Binary, Binary> trigger) Invoked whenMapListenerRequest.RequestTypeisKEY.protected CompletionStage<com.google.protobuf.Empty> BaseNamedCacheServiceImpl.partitionedPutAll(CacheRequestHolder<com.oracle.coherence.grpc.PutAllRequest, Void> holder, Map<Binary, Binary> map) Perform aputAlloperation on a partitioned cache.protected CompletionStage<com.google.protobuf.Empty> BaseNamedCacheServiceImpl.partitionedPutAll(CacheRequestHolder<com.oracle.coherence.grpc.PutAllRequest, Void> holder, Map<Binary, Binary> map) Perform aputAlloperation on a partitioned cache.protected CompletionStage<com.google.protobuf.Empty> BaseNamedCacheServiceImpl.plainPutAll(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAlloperation on a partitioned cache.protected CompletionStage<com.google.protobuf.Empty> BaseNamedCacheServiceImpl.plainPutAll(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAlloperation on a partitioned cache.protected CompletionStage<com.google.protobuf.Empty> BaseNamedCacheServiceImpl.plainPutAll(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAlloperation on a partitioned cache.protected CompletionStage<com.google.protobuf.Empty> BaseNamedCacheServiceImpl.plainPutAll(AsyncNamedCache<Binary, Binary> cache, Map<Binary, Binary> map, long cMillis) Perform aputAlloperation on a partitioned cache. - 
Uses of Binary in com.tangosol.coherence.federation
Methods in com.tangosol.coherence.federation that return types with arguments of type BinaryModifier and TypeMethodDescriptionChangeRecord.getBinaryChangeRecord()ChangeRecord.getBinaryChangeRecord() - 
Uses of Binary in com.tangosol.coherence.rest.io
Methods in com.tangosol.coherence.rest.io that return BinaryModifier and TypeMethodDescriptionBinaryMarshaller.unmarshal(InputStream in, jakarta.ws.rs.core.MediaType mediaType) Methods in com.tangosol.coherence.rest.io with parameters of type BinaryModifier and TypeMethodDescriptionvoidBinaryMarshaller.marshal(Binary value, OutputStream out, jakarta.ws.rs.core.MultivaluedMap<String, Object> httpHeaders)  - 
Uses of Binary in com.tangosol.coherence.rest.util
Fields in com.tangosol.coherence.rest.util declared as BinaryMethods in com.tangosol.coherence.rest.util that return BinaryConstructors in com.tangosol.coherence.rest.util with parameters of type BinaryModifierConstructorDescriptionStaticContent(Binary binContent, String sMediaType) Construct StaticContent instance. - 
Uses of Binary in com.tangosol.io
Fields in com.tangosol.io declared as BinaryModifier and TypeFieldDescriptionprotected static BinaryDecorationOnlyDeltaCompressor.BIN_DECO_ONLYA place-holder Binary value used by the compressor to indicate a decoration-only update.protected static final BinaryAsyncBinaryStore.DELETEDA special token that is used to signify a queued erase operation.protected static final BinaryBinaryDeltaCompressor.DELTA_TRUNCATEA delta value that indicates an empty new value.protected BinarySimpleEvolvable.m_binFutureDataFuture data.static final BinaryAbstractReadBuffer.NO_BINARYAn empty Binary object.static final BinaryAbstractWriteBuffer.NO_BINARYAn empty Binary object.protected static final BinaryBinaryDeltaCompressor.NO_BINARYAn empty Binary object.Methods in com.tangosol.io that return BinaryModifier 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 BinaryReturn 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.Methods in com.tangosol.io that return types with arguments of type BinaryMethods in com.tangosol.io with parameters of type BinaryModifier and TypeMethodDescriptionbooleanBinaryStore.KeySetAware.containsKey(Binary binKey) Return true iff this BinaryStore contains a mapping for the specified key.voidRemove the specified key from the underlying store if present.voidRemove the specified key from the underlying store if present.voidRemove the specified key from the underlying store if present.abstract BinaryReturn 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 voidAsyncBinaryStore.QueueDaemon.processPending(Binary binKey, Binary binValue) Store the specified value under the specific key in the underlying store, or if the value isAsyncBinaryStore.DELETEDthen erase the value from the underlying store.voidAbstractEvolvable.setFutureData(Binary binFuture) Store the unknown remainder of the data stream from which this object is being deserialized.voidEvolvable.setFutureData(Binary binFuture) Store the unknown remainder of the data stream from which this object is being deserialized.voidSimpleEvolvable.setFutureData(Binary binFutureData) Store the unknown remainder of the data stream from which this object is being deserialized.voidStore the specified value under the specific key in the underlying store.voidStore the specified value under the specific key in the underlying store.voidStore the specified value under the specific key in the underlying store. - 
Uses of Binary in com.tangosol.io.bdb
Methods in com.tangosol.io.bdb that return BinaryModifier and TypeMethodDescriptionReturn the value associated with the specified key, or null if the key does not have an associated value in the underlying store.Methods in com.tangosol.io.bdb with parameters of type BinaryModifier and TypeMethodDescriptionvoidRemove 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.voidStore the specified value under the specific key in the underlying store. - 
Uses of Binary in com.tangosol.io.nio
Methods in com.tangosol.io.nio that return BinaryModifier and TypeMethodDescriptionprotected static BinaryInternal 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.Methods in com.tangosol.io.nio with parameters of type BinaryModifier and TypeMethodDescriptionvoidRemove the specified key from the underlying store if present.protected BinaryMap.BlockBinaryMap.findEntryBlock(Binary binKey) Find the Entry block with the specified key.protected BinaryMap.EntryBinaryMap.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.voidUpdate the Entry key in the block.voidUpdate the Entry value in the block.voidStore the specified value under the specific key in the underlying store.Constructors in com.tangosol.io.nio with parameters of type Binary - 
Uses of Binary in com.tangosol.io.pof
Fields in com.tangosol.io.pof declared as BinaryModifier and TypeFieldDescriptionstatic final BinaryPofHelper.BINARY_EMPTYAn empty Binary value.Methods in com.tangosol.io.pof that return BinaryModifier 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 BinaryPofBufferReader.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.Methods in com.tangosol.io.pof with parameters of type BinaryModifier and TypeMethodDescriptionvoidAbstractPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.voidDuplexingPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.voidLoggingPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.voidPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.voidValidatingPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.voidWritingPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.voidPofBufferWriter.writeBinary(int iProp, Binary bin) Write aBinaryproperty to the POF stream.voidPofWriter.writeBinary(int iProp, Binary bin) Write aBinaryproperty to the POF stream.voidPofBufferWriter.UserTypeWriter.writeRemainder(Binary binProps) Write the remaining properties to the POF stream, terminating the writing of the current user type.voidPofBufferWriter.writeRemainder(Binary binProps) Write the remaining properties to the POF stream, terminating the writing of the current user type.voidPofWriter.writeRemainder(Binary binProps) Write the remaining properties to the POF stream, terminating the writing of the current user type.Constructors in com.tangosol.io.pof with parameters of type Binary - 
Uses of Binary in com.tangosol.io.pof.reflect
Methods in com.tangosol.io.pof.reflect that return BinaryModifier 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
Methods in com.tangosol.net that return types with arguments of type BinaryModifier and TypeMethodDescriptionPartitionedService.instantiateKeyToBinaryConverter(ClassLoader loader, boolean fPassThrough)  - 
Uses of Binary in com.tangosol.net.cache
Fields in com.tangosol.net.cache declared as BinaryModifier and TypeFieldDescriptionstatic final BinaryReadWriteBackingMap.BIN_ERASE_PENDINGBinary representation of a decorated null for write-behind remove.protected static final BinaryReadWriteBackingMap.BIN_STORE_PENDINGThe binary form of the decoration indicating that the CacheStore on the primary member has not yet written the value.protected BinaryBackingMapBinaryEntry.m_binKeyThe Binary key.protected BinaryBackingMapBinaryEntry.m_binValueThe Binary value.protected BinaryBackingMapBinaryEntry.m_binValueOrigThe original Binary value.protected static final BinaryReadWriteBackingMap.REMOVEDMarker object used byReadWriteBackingMap.Entryto indicateremovewas called on the Entry.Methods in com.tangosol.net.cache that return BinaryModifier 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 BinaryTranslate the passed Object object into an Binary object.protected BinaryTranslate the passed Object object into an Binary object.protected BinaryTranslate the passed Object object into an Binary object.protected BinaryContinuousQueryCache.toInternal(Object oValue) Serialize the provided value into aBinary.Methods in com.tangosol.net.cache with parameters of type BinaryModifier and TypeMethodDescriptionbooleanReadWriteBackingMap.WriteQueue.accelerateEntryRipe(Binary binKey) Move the ripe time for the queued entry up to accelerate the store operation.voidRemove the specified key from the underlying store if present.voidRemove the specified key from the underlying store if present.voidRemove the specified key from the underlying store if present.protected ObjectBinaryStoreCacheStore.fromBinary(Binary bin) Translate the passed Binary object into an Object object.protected ObjectSerializationMap.fromBinary(Binary bin) Translate the passed Binary object into an Object object.protected ObjectSimpleSerializationMap.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 voidSerializationCache.registerKey(Object oKey, Binary binKey, Binary binValue) Register a new key for the SerializationMap.protected voidSerializationCache.registerKey(Object oKey, Binary binKey, Binary binValue, int cMillis) Register a new key for the SerializationMap.protected voidSerializationMap.registerKey(Object oKey, Binary binKey, Binary binValue) Register a new key for the SerializationMap.voidStore the specified value under the specific key in the underlying store.voidStore the specified value under the specific key in the underlying store.voidStore the specified value under the specific key in the underlying store.voidBackingMapBinaryEntry.updateBinaryValue(Binary binValue) Update the binary value for this entry.voidBackingMapBinaryEntry.updateBinaryValue(Binary binValue, boolean fSynthetic) Update the binary value for this entry.voidReadWriteBackingMap.Entry.updateBinaryValue(Binary binValue) Update the binary value for this entry.Constructors in com.tangosol.net.cache with parameters of type BinaryModifierConstructorDescriptionBackingMapBinaryEntry(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
Methods in com.tangosol.net.topic that return BinaryModifier and TypeMethodDescriptionSubscriber.Element.getBinaryValue()Returns the element's value in serialized form.TopicPublisherException.getBinaryValue()Returns the value that failed to be published in serializedBinaryformat.Methods in com.tangosol.net.topic that return types with arguments of type BinaryModifier 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.Methods in com.tangosol.net.topic with parameters of type BinaryModifier and TypeMethodDescriptionintBinaryElementCalculator.calculateUnits(Binary binElement) intFixedElementCalculator.calculateUnits(Binary binElement) intNamedTopic.ElementCalculator.calculateUnits(Binary binElement) Calculate cost for the specified element.Constructors in com.tangosol.net.topic with parameters of type BinaryModifierConstructorDescriptionTopicPublisherException(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
Methods in com.tangosol.persistence that return BinaryModifier and TypeMethodDescriptionstatic BinaryCachePersistenceHelper.readQuorumRaw(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store) Read the membership information in Binary format from the "META" extent.static BinaryCachePersistenceHelper.writeQuorum(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, PartitionedService service) Write the current membership information to the "META" extent.Methods in com.tangosol.persistence with parameters of type BinaryModifier and TypeMethodDescriptionprotected static ReadBufferCachePersistenceHelper.createIndexRegistrationKey(long lCacheId, Binary binExtractor) Create a key representing an index registration.protected static ReadBufferCachePersistenceHelper.createListenerRegistrationKey(long lMemberId, long lCacheId, Binary binKey) Create a key representing a cache listener registration.protected static ReadBufferCachePersistenceHelper.createLockRegistrationKey(long lHolderId, long lHolderThreadId, long lCacheId, Binary binKey) Create a key representing a cache entry lock.protected static ReadBufferCachePersistenceHelper.createTriggerRegistrationKey(long lCacheId, Binary binTrigger) Create a key representing an trigger registration.static voidCachePersistenceHelper.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 voidCachePersistenceHelper.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 voidCachePersistenceHelper.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 voidCachePersistenceHelper.registerTrigger(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binTrigger, Object oToken) Store the trigger registration in the specified persistent store.static voidCachePersistenceHelper.unregisterIndex(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binExtractor, Object oToken) Clear the index registration from the specified persistent store.static voidCachePersistenceHelper.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 voidCachePersistenceHelper.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 voidCachePersistenceHelper.unregisterTrigger(com.oracle.coherence.persistence.PersistentStore<ReadBuffer> store, long lCacheId, Binary binTrigger, Object oToken) Clear the trigger registration from the specified persistent store.booleanAbstractPersistenceTools.StatsVisitor.visitCacheEntry(long lOldCacheId, Binary binKey, Binary binValue) booleanCachePersistenceHelper.Visitor.visitCacheEntry(long lOldCacheId, Binary binKey, Binary binValue) Apply the visitor to the specified cache entry (key-value pair).booleanAbstractPersistenceTools.StatsVisitor.visitIndex(long lOldCacheId, Binary binExtractor, Binary binComparator) booleanCachePersistenceHelper.Visitor.visitIndex(long lOldCacheId, Binary binExtractor, Binary binComparator) Apply the visitor to the specified cache index.booleanAbstractPersistenceTools.StatsVisitor.visitListener(long lOldCacheId, Binary binKey, long lListenerId, boolean fLite) booleanCachePersistenceHelper.Visitor.visitListener(long lOldCacheId, Binary binKey, long lListenerId, boolean fLite) Apply the visitor to the specified cache entry listener.booleanAbstractPersistenceTools.StatsVisitor.visitLock(long lOldCacheId, Binary binKey, long lHolderId, long lHolderThreadId) booleanCachePersistenceHelper.Visitor.visitLock(long lOldCacheId, Binary binKey, long lHolderId, long lHolderThreadId) Apply the visitor to the specified cache entry lock.booleanAbstractPersistenceTools.StatsVisitor.visitTrigger(long lOldCacheId, Binary binTrigger) booleanCachePersistenceHelper.Visitor.visitTrigger(long lOldCacheId, Binary binTrigger) Apply the visitor to the specified trigger.static voidCachePersistenceHelper.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
Methods in com.tangosol.run.xml that return BinaryModifier 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.Methods in com.tangosol.run.xml with parameters of type BinaryModifier and TypeMethodDescriptionGet the value as binary.Get the value as binary.voidSet the binary value.voidSet the binary value. - 
Uses of Binary in com.tangosol.util
Fields in com.tangosol.util declared as BinaryModifier and TypeFieldDescriptionstatic final BinaryBinary.EMPTYAn empty Binary.static final Binary[]ExternalizableHelper.EMPTY_BINARY_ARRAYAn empty array of Binary objects.static final BinaryBinary.FALSEA Binary representation ofBoolean.FALSEvalue.static final BinaryBinary.TRUEA Binary representation ofBoolean.TRUEvalue.Methods in com.tangosol.util that return BinaryModifier and TypeMethodDescriptionstatic BinaryExternalizableHelper.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 BinaryDecorate the passed value with the specified decoration and return the resulting Binary.static BinaryDeprecated.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 BinaryExternalizableHelper.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 BinaryBase.getRandomBinary(int cbMin, int cbMax) Generates a random-length Binary within the length bounds provided whose contents are random bytes.static BinaryBase.getRandomBinary(int cbMin, int cbMax, byte... abHead) Generates a random-length Binary includingabHeadat the head of the Binary, in addition to random bytes within the length bounds provided.static BinaryExternalizableHelper.getUndecorated(Binary bin) Deprecated.as of Coherence 3.7.2static BinaryJoin an array of Binaries into a single Binary.Unsafe.newBinary(byte[] ab, int of, int cb) Return a newBinaryinstance backed by the specified byte[] beginning at the specified offset and of the specified length.static BinaryBinary.readBinary(DataInput input) Read a Binary from the specified DataInput.static BinaryBinary.readBinary(DataInputStream in) Read a Binary from the specified DataInputStream.static BinaryBinary.readBinary(File file) Read a Binary from the specified File.static BinaryBinary.readBinary(InputStream in) Read a Binary from the specified InputStream.static BinaryBinary.readBinary(InputStream in, int cb) Read a Binary from the specified InputStream.static BinaryBinary.readBinary(URL url) Read a Binary from the specified URL.static BinaryBinary.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 BinaryExternalizableHelper.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 BinaryWrite an object into a Binary object.static BinaryExternalizableHelper.toBinary(Object o, Serializer serializer) Write an object into a Binary object using the specified Serializer.static BinaryExternalizableHelper.toBinary(Object o, Serializer serializer, WriteBuffer buf) Write an object into a Binary object using the specified Serializer.static BinaryExternalizableHelper.toLiteBinary(ExternalizableLite o) Write an ExternalizableLite object into a Binary object.static BinaryExternalizableHelper.undecorate(Binary bin, int nId) Deprecated.as of Coherence 3.7.2Methods in com.tangosol.util with parameters of type BinaryModifier and TypeMethodDescriptionintCompares this object with the specified object for order.Concatenate the passed Binary onto this Binary.static BinaryDecorate the passed value with the specified decoration and return the resulting Binary.static BinaryDeprecated.as of Coherence 3.7.2booleanTests if this Binary object ends with the specified suffix.static <T> TExternalizableHelper.fromBinary(Binary bin) Read an object from a Binary object.static <T> TExternalizableHelper.fromBinary(Binary bin, Serializer serializer) Read an object from a Binary object using the specified Serializer.static <T> TExternalizableHelper.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> TExternalizableHelper.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> TExternalizableHelper.fromBinary(Binary bin, Serializer serializer, Class<T> clazz) Read an object from a Binary object using the specified Serializer and expected class.static <T> TExternalizableHelper.fromBinary(Binary bin, ClassLoader loader) Read an object from a Binary object.intUnsafe.getArrayOffset(Binary bin) Return the offset into theunderlying byte arrayfor the specified Binary.byte[]Unsafe.getByteArray(Binary bin) Return the underlying byte[] for the specified Binary.static BinaryExternalizableHelper.getDecoration(Binary bin, int nId) Deprecated.as of Coherence 3.7.2static BinaryExternalizableHelper.getUndecorated(Binary bin) Deprecated.as of Coherence 3.7.2intReturns the offset within this Binary object of the first occurrence of the specified Binary.intReturns the offset within this Binary object of the first occurrence of the specified Binary, starting the search at the specified offset.static BinaryJoin an array of Binaries into a single Binary.intBinary.lastIndexOf(Binary bin) Returns the offset within this Binary object of the last occurrence of the specified Binary.intBinary.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.voidNullImplementation.NullPofHandler.onOctetString(int iPos, Binary bin) Report that a octet string value has been encountered in the POF stream.booleanBinary.regionMatches(int ofThis, Binary that, int ofThat, int cb) Tests if two Binary regions are equal.static BinaryExternalizableHelper.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.booleanBinary.startsWith(Binary bin) Tests if this Binary object starts with the specified prefix.booleanBinary.startsWith(Binary bin, int ofFrom) Tests if this Binary object starts with the specified prefix beginning a specified offset.static BinaryExternalizableHelper.undecorate(Binary bin, int nId) Deprecated.as of Coherence 3.7.2voidBinaryEntry.updateBinaryValue(Binary binValue) Update the binary value for this entry.voidBinaryEntry.updateBinaryValue(Binary binValue, boolean fSynthetic) Update the binary value for this entry.voidConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry.updateBinaryValue(Binary binValue) Update the binary value for this entry.voidConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry.updateBinaryValue(Binary binValue, boolean fSynthetic) Update the binary value for this entry.voidInvocableMapHelper.RoutingBinaryEntry.updateBinaryValue(Binary binValue) voidInvocableMapHelper.RoutingBinaryEntry.updateBinaryValue(Binary binValue, boolean fSynthetic) Constructors in com.tangosol.util with parameters of type Binary