Modifier and Type | Method and Description |
---|---|
com.github.benmanes.caffeine.cache.LoadingCache<Long,ILogData> |
LogUnitServer.getDataCache() |
Modifier and Type | Method and Description |
---|---|
void |
MultiSMREntry.setEntry(ILogData entry)
Deprecated.
|
void |
MultiObjectSMREntry.setEntry(ILogData entry)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
LogData
Created by mwei on 8/15/16.
|
Modifier and Type | Method and Description |
---|---|
ILogData |
ILogData.SerializationHandle.getSerialized()
Explicitly request the serialized form of this log data
which only exists for the lifetime of this handle.
|
Modifier and Type | Method and Description |
---|---|
default int |
ILogData.compareTo(ILogData o) |
Constructor and Description |
---|
SerializationHandle(ILogData data)
Create a new serialized handle with a reference
to the log data.
|
Modifier and Type | Method and Description |
---|---|
static LogEntry |
RecoveryUtils.deserializeLogData(CorfuRuntime runtime,
ILogData logData)
Deserialize a logData by getting the logEntry
Getting the underlying logEntry should trigger deserialization only once.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Boolean> |
LogUnitClient.write(ILogData payload)
Asynchronously write to the logging unit.
|
Modifier and Type | Method and Description |
---|---|
ILogData |
AddressSpaceView.fetch(long address)
Explicitly fetch a given address, bypassing the cache.
|
ILogData |
AddressSpaceView.peek(long address)
Directly read from the log, returning any
committed value, or NULL, if no value has
been committed.
|
ILogData |
AddressSpaceView.predictiveReadRange(Long nextRead,
List<Long> addresses)
This method reads a batch of addresses if 'nextRead' is not found in the cache.
|
ILogData |
AddressSpaceView.read(long address)
Read the given object from an address and streams.
|
Modifier and Type | Method and Description |
---|---|
Map<Long,ILogData> |
AddressSpaceView.fetchAll(Iterable<Long> addresses,
boolean waitForWrite)
Fetch a collection of addresses for insertion into the cache.
|
Map<Long,ILogData> |
AddressSpaceView.read(Iterable<Long> addresses)
Read the given object from a range of addresses.
|
Map<Long,ILogData> |
AddressSpaceView.read(Iterable<Long> addresses,
boolean waitForWrite)
Read the given object from a range of addresses.
|
Modifier and Type | Method and Description |
---|---|
ILogData |
QuorumReplicationProtocol.peek(RuntimeLayout runtimeLayout,
long address)
Peek data from a given address.
|
ILogData |
IReplicationProtocol.peek(RuntimeLayout runtimeLayout,
long globalAddress)
Peek data from a given address.
|
ILogData |
ChainReplicationProtocol.peek(RuntimeLayout runtimeLayout,
long globalAddress)
Peek data from a given address.
|
ILogData |
ReadWaitHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
AlwaysHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
IHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
NeverHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
IReplicationProtocol.read(RuntimeLayout runtimeLayout,
long globalAddress)
Read data from a given address.
|
ILogData |
AbstractReplicationProtocol.read(RuntimeLayout runtimeLayout,
long globalAddress)
Read data from a given address.
|
Modifier and Type | Method and Description |
---|---|
Map<Long,ILogData> |
QuorumReplicationProtocol.readAll(RuntimeLayout runtimeLayout,
List<Long> addresses,
boolean waitForWrite)
Read data from all the given addresses.
|
Map<Long,ILogData> |
IReplicationProtocol.readAll(RuntimeLayout runtimeLayout,
List<Long> addresses,
boolean waitForWrite)
Read data from all the given addresses.
|
Map<Long,ILogData> |
ChainReplicationProtocol.readAll(RuntimeLayout runtimeLayout,
List<Long> addresses,
boolean waitForWrite)
Reads a list of global addresses from the chain of log unit servers.
|
Modifier and Type | Method and Description |
---|---|
void |
QuorumReplicationProtocol.write(RuntimeLayout runtimeLayout,
ILogData data)
Write data to the log at the given address.
|
void |
IReplicationProtocol.write(RuntimeLayout runtimeLayout,
ILogData data)
Write data to the log at the given address.
|
void |
ChainReplicationProtocol.write(RuntimeLayout runtimeLayout,
ILogData data)
Write data to the log at the given address.
|
Modifier and Type | Method and Description |
---|---|
ILogData |
ReadWaitHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
AlwaysHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
IHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
ILogData |
NeverHoleFillPolicy.peekUntilHoleFillRequired(long address,
Function<Long,ILogData> peekFunction)
Apply the given peek function until hole filling is required or
committed data is returned.
|
Modifier and Type | Method and Description |
---|---|
ILogData |
AbstractQueuedStreamView.current()
Retrieve the current entry in the stream, which was the entry previously
returned by a call to next() or previous().
|
ILogData |
ThreadSafeStreamView.current() |
ILogData |
IStreamView.current()
Retrieve the current entry in the stream, which was the entry previously
returned by a call to next() or previous().
|
protected ILogData |
AbstractQueuedStreamView.getNextEntry(org.corfudb.runtime.view.stream.AbstractQueuedStreamView.QueuedStreamContext context,
long maxGlobal)
Retrieve the next entry in the stream, given the context.
|
protected abstract ILogData |
AbstractContextStreamView.getNextEntry(T context,
long maxGlobal)
Retrieve the next entry in the stream, given the context.
|
ILogData |
ThreadSafeStreamView.next() |
default ILogData |
IStreamView.next()
Retrieve the next entry from this stream, up to the tail of the stream
If there are no entries present, this function will return NULL.
|
ILogData |
AbstractContextStreamView.nextUpTo(long maxGlobal)
Retrieve the next entry from this stream, up to the address given or the
tail of the stream.
|
ILogData |
ThreadSafeStreamView.nextUpTo(long maxGlobal) |
ILogData |
IStreamView.nextUpTo(long maxGlobal)
Retrieve the next entry from this stream, up to the address given or the
tail of the stream.
|
ILogData |
AbstractQueuedStreamView.previous()
Retrieve the previous entry in the stream.
|
ILogData |
ThreadSafeStreamView.previous() |
ILogData |
IStreamView.previous()
Retrieve the previous entry in the stream.
|
protected ILogData |
AbstractQueuedStreamView.read(long address) |
protected ILogData |
AbstractQueuedStreamView.read(long address,
long readStartTime)
Reads data from an address in the address space.
|
protected ILogData |
AbstractQueuedStreamView.readRange(long address,
List<Long> addresses) |
protected ILogData |
BackpointerStreamView.removeFromQueue(NavigableSet<Long> queue) |
protected abstract ILogData |
AbstractQueuedStreamView.removeFromQueue(NavigableSet<Long> queue)
Remove next entry from the queue.
|
protected ILogData |
AddressMapStreamView.removeFromQueue(NavigableSet<Long> queue) |
Modifier and Type | Method and Description |
---|---|
Comparator<? super ILogData> |
StreamSpliterator.getComparator() |
protected List<ILogData> |
AbstractQueuedStreamView.getNextEntries(org.corfudb.runtime.view.stream.AbstractQueuedStreamView.QueuedStreamContext context,
long maxGlobal,
Function<ILogData,Boolean> contextCheckFn)
Retrieve the next entries in the stream, given the context.
|
protected List<ILogData> |
AbstractContextStreamView.getNextEntries(T context,
long maxGlobal,
Function<ILogData,Boolean> contextCheckFn)
Retrieve the next entries in the stream, given the context.
|
protected List<ILogData> |
AbstractQueuedStreamView.readAll(List<Long> addresses) |
default List<ILogData> |
IStreamView.remaining()
Retrieve all of the entries from this stream, up to the tail of this
stream.
|
List<ILogData> |
AbstractContextStreamView.remainingUpTo(long maxGlobal)
Retrieve all of the entries from this stream, up to the address given or
the tail of the stream.
|
List<ILogData> |
ThreadSafeStreamView.remainingUpTo(long maxGlobal) |
List<ILogData> |
IStreamView.remainingUpTo(long maxGlobal)
Retrieve all of the entries from this stream, up to the address given or
the tail of the stream.
|
default Spliterator<ILogData> |
IStreamView.spliterator()
Get a spliterator for this stream view
|
default Spliterator<ILogData> |
IStreamView.spliteratorUpTo(long maxGlobal)
Get a spliterator for this stream view, limiting the return
values to a specified global address.
|
default Stream<ILogData> |
IStreamView.stream()
Get a Java stream from this stream view.
|
default Stream<ILogData> |
IStreamView.streamUpTo(long maxGlobal)
Get a Java stream from this stream view, limiting
reads to a specified global address.
|
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractQueuedStreamView.addToResolvedQueue(org.corfudb.runtime.view.stream.AbstractQueuedStreamView.QueuedStreamContext context,
long globalAddress,
ILogData ld)
Add the given address to the resolved queue of the
given context.
|
protected boolean |
AbstractContextStreamView.doesEntryUpdateContext(ILogData data)
Check whether the given entry updates the context.
|
protected boolean |
AbstractContextStreamView.processEntryForContext(ILogData data)
Check if the given entry adds a new context, and update
the global pointer.
|
protected AbstractQueuedStreamView.BackpointerOp |
AbstractQueuedStreamView.resolveCheckpoint(org.corfudb.runtime.view.stream.AbstractQueuedStreamView.QueuedStreamContext context,
ILogData data,
long maxGlobal) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
BackpointerStreamView.discoverAddressSpace(UUID streamId,
NavigableSet<Long> queue,
long startAddress,
long stopAddress,
Function<ILogData,AbstractQueuedStreamView.BackpointerOp> filter,
boolean checkpoint,
long maxGlobal) |
protected abstract boolean |
AbstractQueuedStreamView.discoverAddressSpace(UUID streamId,
NavigableSet<Long> queue,
long startAddress,
long stopAddress,
Function<ILogData,AbstractQueuedStreamView.BackpointerOp> filter,
boolean checkpoint,
long maxGlobal)
Defines the strategy to discover addresses belonging to this stream.
|
protected boolean |
AddressMapStreamView.discoverAddressSpace(UUID streamId,
NavigableSet<Long> queue,
long startAddress,
long stopAddress,
Function<ILogData,AbstractQueuedStreamView.BackpointerOp> filter,
boolean checkpoint,
long maxGlobal)
Retrieve this stream's address map, i.e., a map of all addresses corresponding to this stream between
(stop address, start address] and return a boolean indicating if addresses were found in this range.
|
protected List<ILogData> |
AbstractQueuedStreamView.getNextEntries(org.corfudb.runtime.view.stream.AbstractQueuedStreamView.QueuedStreamContext context,
long maxGlobal,
Function<ILogData,Boolean> contextCheckFn)
Retrieve the next entries in the stream, given the context.
|
protected List<ILogData> |
AbstractContextStreamView.getNextEntries(T context,
long maxGlobal,
Function<ILogData,Boolean> contextCheckFn)
Retrieve the next entries in the stream, given the context.
|
boolean |
StreamSpliterator.tryAdvance(Consumer<? super ILogData> action) |
Modifier and Type | Method and Description |
---|---|
static void |
Utils.printLogAnatomy(CorfuRuntime runtime,
ILogData logData)
Print the anatomy of a LogData
|
Copyright © 2019 CorfuDB. All rights reserved.