- abort() - Method in class org.corfudb.security.sasl.plaintext.PlainTextLoginModule
-
- AbortCause - Enum in org.corfudb.runtime.exceptions
-
Created by dalia on 4/8/17.
- ABORTED - Static variable in class org.corfudb.runtime.view.Address
-
Aborted request constant.
- ABORTED_ADDRESS - Static variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Constant for a transaction which has been aborted.
- abortTransaction(TransactionAbortedException) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Forcefully abort the transaction.
- AbstractAction() - Constructor for class org.corfudb.universe.scenario.action.Action.AbstractAction
-
- AbstractContextStreamView<T extends AbstractStreamContext> - Class in org.corfudb.runtime.view.stream
-
An abstract context stream view maintains contexts, which are used to
implement copy-on-write entries.
- AbstractContextStreamView(CorfuRuntime, UUID, BiFunction<UUID, Long, T>) - Constructor for class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Create a new abstract context stream view.
- AbstractCorfuCluster<P extends CorfuClusterParams,U extends UniverseParams> - Class in org.corfudb.universe.group.cluster
-
- AbstractCorfuCluster(P, U) - Constructor for class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
- AbstractCorfuServer<T extends CorfuServerParams,U extends UniverseParams> - Class in org.corfudb.universe.node.server
-
- AbstractCorfuServer(T, U) - Constructor for class org.corfudb.universe.node.server.AbstractCorfuServer
-
- AbstractCorfuWrapper<T> - Class in org.corfudb.runtime.object
-
A Corfu container object is a container for other Corfu objects.
- AbstractCorfuWrapper() - Constructor for class org.corfudb.runtime.object.AbstractCorfuWrapper
-
- AbstractQueuedStreamView - Class in org.corfudb.runtime.view.stream
-
The abstract queued stream view implements a stream backed by a read queue.
- AbstractQueuedStreamView(CorfuRuntime, UUID) - Constructor for class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Create a new queued stream view.
- AbstractQueuedStreamView.BackpointerOp - Enum in org.corfudb.runtime.view.stream
-
- AbstractReplicationProtocol - Class in org.corfudb.runtime.view.replication
-
Created by mwei on 4/6/17.
- AbstractReplicationProtocol(IHoleFillPolicy) - Constructor for class org.corfudb.runtime.view.replication.AbstractReplicationProtocol
-
Build the replication protocol using the given hole filling policy.
- AbstractServer - Class in org.corfudb.infrastructure
-
Created by mwei on 12/4/15.
- AbstractServer() - Constructor for class org.corfudb.infrastructure.AbstractServer
-
- AbstractServer.ServerState - Enum in org.corfudb.infrastructure
-
The server state.
- AbstractSpec(String) - Constructor for class org.corfudb.universe.scenario.spec.Spec.AbstractSpec
-
- AbstractStreamContext - Class in org.corfudb.runtime.view.stream
-
A data class which keeps data for each stream context.
- AbstractStreamContext(UUID, long) - Constructor for class org.corfudb.runtime.view.stream.AbstractStreamContext
-
Generate a new stream context given the id of the stream and the
maximum address to read to.
- AbstractTransactionalContext - Class in org.corfudb.runtime.object.transactions
-
Represents a transactional context.
- AbstractUniverse<P extends UniverseParams> - Class in org.corfudb.universe.universe
-
- AbstractUniverse(P) - Constructor for class org.corfudb.universe.universe.AbstractUniverse
-
- AbstractUniverseFixture() - Constructor for class org.corfudb.universe.scenario.fixture.Fixtures.AbstractUniverseFixture
-
- AbstractView - Class in org.corfudb.runtime.view
-
All views inherit from AbstractView.
- AbstractView(CorfuRuntime) - Constructor for class org.corfudb.runtime.view.AbstractView
-
- AbstractView.LayoutFunction<V,R,A extends Throwable,B extends Throwable,C extends Throwable,D extends Throwable> - Interface in org.corfudb.runtime.view
-
- access(ICorfuSMRAccess<R, T>, Object[]) - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Access the state of the object.
- access(T) - Method in interface org.corfudb.runtime.object.ICorfuSMRAccess
-
Access the state of the SMR object.
- access(ICorfuSMRAccess<R, T>, Object[]) - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Access the state of the object.
- access(ICorfuSMRProxyInternal<T>, ICorfuSMRAccess<R, T>, Object[]) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Access the state of the object.
- access(ICorfuSMRProxyInternal<T>, ICorfuSMRAccess<R, T>, Object[]) - Method in class org.corfudb.runtime.object.transactions.OptimisticTransactionalContext
-
Access within optimistic transactional context is implemented
in via proxy.access() as follows:
- access(ICorfuSMRProxyInternal<T>, ICorfuSMRAccess<R, T>, Object[]) - Method in class org.corfudb.runtime.object.transactions.SnapshotTransactionalContext
-
Access the state of the object.
- access(Function<VersionLockedObject<T>, Boolean>, Consumer<VersionLockedObject<T>>, Function<T, R>) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Access the internal state of the object, trying first to optimistically access
the object, then obtaining a write lock the optimistic access fails.
- Accessor - Annotation Type in org.corfudb.annotations
-
An accessor marks a method which accesses
the state of a Corfu object.
- acquireBuffer() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- acquireBuffer() - Method in class org.corfudb.protocols.wireprotocol.LogData
-
- acquireReadLock(Long) - Method in class org.corfudb.infrastructure.log.MultiReadWriteLock
-
Acquire a read lock.
- acquireWriteLock(Long) - Method in class org.corfudb.infrastructure.log.MultiReadWriteLock
-
Acquire a write lock.
- Action - Class in org.corfudb.infrastructure.orchestrator
-
A workflow action.
- Action() - Constructor for class org.corfudb.infrastructure.orchestrator.Action
-
- action() - Method in class org.corfudb.samples.SimpleUseBaseCorfuCollections
-
- action() - Method in class org.corfudb.samples.SimpleUseCustomBaseCorfuObject
-
- Action<R> - Interface in org.corfudb.universe.scenario.action
-
Provides an interface for executable actions used in scenarios.
- action(Action<R>) - Method in class org.corfudb.universe.scenario.Scenario.ScenarioTest
-
- action(Action.AbstractAction<R>) - Method in class org.corfudb.universe.scenario.Scenario.ScenarioTest
-
- Action.AbstractAction<R> - Class in org.corfudb.universe.scenario.action
-
Actions do some work and often it changes
Universe
state,
in most cases an action needs to have a
Universe
as a dependency.
- ActionStatus - Enum in org.corfudb.infrastructure.orchestrator
-
The possible states in which an action can be in.
- add(ICorfuSMRProxyInternal, Object[]) - Method in class org.corfudb.runtime.object.transactions.ConflictSetInfo
-
Add an operation into this conflict set.
- add(ICorfuSMRProxyInternal, SMREntry, Object[]) - Method in class org.corfudb.runtime.object.transactions.WriteSetInfo
-
- add(Node.NodeParams) - Method in class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
- add(CorfuServerParams) - Method in class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- add(Node.NodeParams) - Method in interface org.corfudb.universe.group.Group
-
- add(Group.GroupParams) - Method in class org.corfudb.universe.universe.docker.DockerUniverse
-
- add(Group.GroupParams) - Method in class org.corfudb.universe.universe.process.ProcessUniverse
-
- add(Group.GroupParams) - Method in interface org.corfudb.universe.universe.Universe
-
- add(Group.GroupParams) - Method in class org.corfudb.universe.universe.UniverseParams
-
- add(Group.GroupParams) - Method in class org.corfudb.universe.universe.vm.VmUniverse
-
- add(E) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- addAddress(long) - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Add an address to this address space.
- addAll(Collection<? extends E>) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- addAllMaps(Collection<T>) - Method in class org.corfudb.runtime.MultiCheckpointWriter
-
Add map(s) to the list of maps to be checkpointed by this class.
- addCacheMeasurerFor(MetricRegistry, Cache) - Static method in class org.corfudb.util.MetricsUtils
-
This method adds different properties of provided instance of Cache
to the
indicated metrics registry.
- addClient(IClient) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Add a new client to the router.
- addClient(IClient) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Add a new client to the router.
- addConflictFieldFromFunctionToMethod(MethodSpec.Builder, String, String, ExecutableElement) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
-
Add a conflict field to the method.
- addConflictFieldToMethod(MethodSpec.Builder, String, ExecutableElement) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
-
Add a conflict field to the method.
- addCustomTypeStream(UUID, ObjectBuilder) - Method in class org.corfudb.recovery.FastObjectLoader
-
- addForwardResolution(String, InetAddress) - Method in class org.corfudb.universe.universe.docker.FakeDns
-
- addHandler(CorfuMsgType, CorfuMsgHandler.Handler<T>) - Method in class org.corfudb.infrastructure.CorfuMsgHandler
-
Add a handler to this message handler.
- addHandler(CorfuMsgType, ClientMsgHandler.Handler<T>) - Method in class org.corfudb.runtime.clients.ClientMsgHandler
-
Add a handler to this message handler.
- addIndexerToCorfuTableStream(String, CorfuTable.IndexRegistry) - Method in class org.corfudb.recovery.FastObjectLoader
-
Add an indexer to a stream (that backs a CorfuTable)
- addLayoutServer(String) - Method in class org.corfudb.runtime.CorfuRuntime
-
Add a layout server to the list of servers known by the CorfuRuntime.
- addLayoutServer(String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Adds a new layout server.
- addLogUnitReplica(Layout, String, int) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Add the log unit to the segment to increase redundancy.
- addLogunitServer(int, long, String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Adds a new logunit server.
- addLogunitServerToSegment(String, int, int) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Add a log unit server to a specific stripe in a specific segment.
- addMap(T) - Method in class org.corfudb.runtime.MultiCheckpointWriter
-
Add a map to the list of maps to be checkpointed by this class.
- addMemoryMeasurerFor(MetricRegistry, Object) - Static method in class org.corfudb.util.MetricsUtils
-
This method creates object size gauge and registers it to the metrics registry.
- addNode(Layout, String, boolean, boolean, boolean, boolean, int) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Adds a new node to the existing layout.
- addNode(String, int, Duration, Duration) - Method in class org.corfudb.runtime.view.ManagementView
-
Add a new node to the existing cluster.
- AddNode - Class in org.corfudb.runtime.view.workflows
-
A workflow request that makes an orchestrator call to add a new node to
the cluster.
- AddNode(String, CorfuRuntime, int, Duration, Duration) - Constructor for class org.corfudb.runtime.view.workflows.AddNode
-
- AddNodeRequest - Class in org.corfudb.protocols.wireprotocol.orchestrator
-
An orchestrator request to add a new node to the cluster.
- AddNodeRequest(String) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.AddNodeRequest
-
- AddNodeRequest(byte[]) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.AddNodeRequest
-
- addNodeRequest(String) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Send a add node request to an orchestrator
- AddNodeWorkflow - Class in org.corfudb.infrastructure.orchestrator.workflows
-
A definition of a workflow that adds a new node to the cluster.
- AddNodeWorkflow(AddNodeRequest) - Constructor for class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow
-
Creates a new add node workflow from a request.
- AddNodeWorkflow.BootstrapNode - Class in org.corfudb.infrastructure.orchestrator.workflows
-
Bootstrap the new node to be added to the cluster, or ignore
bootstrap if it's already bootstrapped.
- AddNodeWorkflow.RestoreRedundancy - Class in org.corfudb.infrastructure.orchestrator.workflows
-
The new server is caught up with all data.
- addOption(ObjectOpenOptions) - Method in class org.corfudb.runtime.view.ObjectBuilder
-
Add option to object builder.
- Address - Class in org.corfudb.runtime.view
-
Currently, this class holds static constants used
to represent addresses.
- Address() - Constructor for class org.corfudb.runtime.view.Address
-
- AddressMapStreamView - Class in org.corfudb.runtime.view.stream
-
A view of a stream implemented with address maps.
- AddressMapStreamView(CorfuRuntime, UUID, StreamOptions) - Constructor for class org.corfudb.runtime.view.stream.AddressMapStreamView
-
Create a new address map stream view.
- AddressMapStreamView(CorfuRuntime, UUID) - Constructor for class org.corfudb.runtime.view.stream.AddressMapStreamView
-
- AddressMetaData - Class in org.corfudb.infrastructure.log
-
Created by maithem on 3/14/17.
- AddressMetaData(int, int, long) - Constructor for class org.corfudb.infrastructure.log.AddressMetaData
-
Returns a metadata object for an address.
- AddressSpaceView - Class in org.corfudb.runtime.view
-
A view of the address space implemented by Corfu.
- AddressSpaceView(CorfuRuntime) - Constructor for class org.corfudb.runtime.view.AddressSpaceView
-
Constructor for the Address Space View.
- addReverseResolution(InetAddress, String) - Method in class org.corfudb.universe.universe.docker.FakeDns
-
- addSequencerServer(String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Adds a new sequencer server.
- addServer(AbstractServer) - Method in interface org.corfudb.infrastructure.IServerRouter
-
Register a server to route messages to.
- addServer(AbstractServer) - Method in class org.corfudb.infrastructure.NettyServerRouter
-
- addShutdownHook(String) - Method in class org.corfudb.universe.util.DockerManager
-
- addStreamsToLoad(List<String>) - Method in class org.corfudb.recovery.FastObjectLoader
-
Enable whiteList mode where we only reconstruct
the streams provided through this api.
- addStreamToIgnore(String) - Method in class org.corfudb.recovery.FastObjectLoader
-
- addTask(BatchWriterOperation.Type, CorfuPayloadMsg) - Method in class org.corfudb.infrastructure.BatchProcessor
-
Add a task to the processor.
- addTo(UUID, SMREntry) - Method in class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
Add one SMR-update to one object's update-list.
- addTo(SMREntry) - Method in class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- addToReadSet(ICorfuSMRProxyInternal, Object[]) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Add the proxy and conflict-params information to our read set.
- addToReadSet(ICorfuSMRProxyInternal, Object[]) - Method in class org.corfudb.runtime.object.transactions.WriteAfterWriteTransactionalContext
-
- addToResolvedQueue(AbstractQueuedStreamView.QueuedStreamContext, long, ILogData) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Add the given address to the resolved queue of the
given context.
- addTransaction(AbstractTransactionalContext) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Add a given transaction to this transactional context, merging
the read and write sets.
- addTransaction(AbstractTransactionalContext) - Method in class org.corfudb.runtime.object.transactions.OptimisticTransactionalContext
-
Commit a transaction into this transaction by merging the read/write
sets.
- addTransaction(AbstractTransactionalContext) - Method in class org.corfudb.runtime.object.transactions.SnapshotTransactionalContext
-
- addUnresponsiveServers(Set<String>) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Adds unresponsive servers in the list.
- ALL_STREAMS - Static variable in class org.corfudb.protocols.wireprotocol.StreamsAddressRequest
-
- ALL_STREAMS_TAIL - Static variable in class org.corfudb.protocols.wireprotocol.TailsRequest
-
- allOf(Collection<CompletableFuture<T>>) - Static method in class org.corfudb.util.CFUtils
-
- AlreadyBootstrappedException - Exception in org.corfudb.runtime.exceptions
-
Created by mwei on 6/17/16.
- AlreadyBootstrappedException() - Constructor for exception org.corfudb.runtime.exceptions.AlreadyBootstrappedException
-
- AlwaysHoleFillPolicy - Class in org.corfudb.runtime.view.replication
-
A simple hole filling policy which aggressively
fills holes whenever there is a failed read.
- AlwaysHoleFillPolicy() - Constructor for class org.corfudb.runtime.view.replication.AlwaysHoleFillPolicy
-
- append(List<LogData>) - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- append(long, LogData) - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- append(long, LogData) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Append an entry to the stream log.
- append(List<LogData>) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Append a range of consecutive entries ordered by their addresses.
- append(List<LogData>) - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- append(long, LogData) - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- append(SMREntry, Function<TokenResponse, Boolean>, Function<TokenResponse, Boolean>) - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
Append a SMREntry to the stream, returning the global address
it was written at.
- append(SMREntry, Function<TokenResponse, Boolean>, Function<TokenResponse, Boolean>) - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
Append a SMREntry to the stream, returning the global address
it was written at.
- append(SMREntry, Function<TokenResponse, Boolean>, Function<TokenResponse, Boolean>) - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- append(Object, Function<TokenResponse, Boolean>, Function<TokenResponse, Boolean>) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Append an object to the stream, returning the global address
it was written at.
- append(Object, Function<TokenResponse, Boolean>, Function<TokenResponse, Boolean>) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Append an object to the stream, returning the global address
it was written at.
- append(Object) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Append an object to the stream, returning the global address it was
written at.
- append(Object, Function<TokenResponse, Boolean>, Function<TokenResponse, Boolean>) - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- append(Object, TxResolutionInfo, CacheOption, UUID...) - Method in class org.corfudb.runtime.view.StreamsView
-
Append to multiple streams simultaneously, possibly providing
information on how to resolve conflicts.
- append(Object, TxResolutionInfo, UUID...) - Method in class org.corfudb.runtime.view.StreamsView
-
Append to multiple streams and caches the result.
- appendCheckpoint() - Method in class org.corfudb.runtime.CheckpointWriter
-
- appendCheckpoints(CorfuRuntime, String) - Method in class org.corfudb.runtime.MultiCheckpointWriter
-
Checkpoint multiple SMRMaps.
- AppendException - Exception in org.corfudb.runtime.exceptions
-
Created by maithem on 8/22/17.
- AppendException() - Constructor for exception org.corfudb.runtime.exceptions.AppendException
-
- appendObjectState(Set<Map.Entry>) - Method in class org.corfudb.runtime.CheckpointWriter
-
Append zero or more CONTINUATION records to this
object's stream.
- ApplianceManager - Class in org.corfudb.universe.universe.vm
-
Managing vm appliances: deploy vm's, stop, restart, destroy.
- ApplianceManager() - Constructor for class org.corfudb.universe.universe.vm.ApplianceManager
-
- apply(CorfuMsg) - Method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
- apply(RuntimeLayout) - Method in interface org.corfudb.runtime.view.AbstractView.LayoutFunction
-
- applyUndoRecordUnsafe(SMREntry) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Given a SMR entry with an undo record, undo the update.
- applyUpdateToStreamUnsafe(SMREntry, long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Apply an SMREntry to the version object, while
doing bookkeeping for the underlying stream.
- applyUpdateUnsafe(SMREntry) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Apply an SMR update to the object, possibly optimistically.
- asBase64(UUID) - Static method in class org.corfudb.util.UuidUtils
-
Generate a base64 URL-safe string from a given UUID.
- asByte() - Method in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointDictKey
-
- asByte() - Method in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointEntryType
-
- asByte() - Method in enum org.corfudb.protocols.logprotocol.LogEntry.LogEntryType
-
- asByte() - Method in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
- asByte() - Method in enum org.corfudb.protocols.wireprotocol.IMetadata.LogUnitMetadataType
-
- asByte() - Method in interface org.corfudb.protocols.wireprotocol.ITypedEnum
-
- asJSONString() - Method in class org.corfudb.runtime.view.Layout
-
Get the layout as a JSON string.
- assertAppendPermittedUnsafe(long, LogData) - Method in interface org.corfudb.infrastructure.log.StreamLogWithRankedAddressSpace
-
Check whether the data can be appended to a given log address.
- assignResponsiveSequencerAsPrimary(Set<String>) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Moves a responsive server to the top of the sequencer server list.
- asyncSealServers(RuntimeLayout) - Static method in class org.corfudb.runtime.view.SealServersHelper
-
Asynchronously seal all servers in layout by setting remote epochs.
- asyncSequencerBootstrap(Layout, ExecutorService) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Triggers a new task to bootstrap the sequencer for the specified layout.
- attemptClusterRecovery(Layout) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
On restart, if MANAGEMENT_LAYOUT exists in the local datastore.
- AutoCloseRwLock(ReadWriteLock) - Constructor for class org.corfudb.util.LockUtils.AutoCloseRwLock
-
- CacheOption - Enum in org.corfudb.runtime.view
-
Cache options for write operations.
- cancel(boolean) - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
- cast(Object) - Static method in class org.corfudb.universe.util.ClassUtils
-
- cast(Object, Class<T>) - Static method in class org.corfudb.universe.util.ClassUtils
-
- CFUtils - Class in org.corfudb.util
-
Created by mwei on 9/15/15.
- ChainReplicationProtocol - Class in org.corfudb.runtime.view.replication
-
Created by mwei on 4/6/17.
- ChainReplicationProtocol(IHoleFillPolicy) - Constructor for class org.corfudb.runtime.view.replication.ChainReplicationProtocol
-
- channelActive(ChannelHandlerContext) - Method in class org.corfudb.infrastructure.ServerHandshakeHandler
-
Channel event that is triggered when a new connected channel is created.
- channelActive(ChannelHandlerContext) - Method in class org.corfudb.protocols.wireprotocol.ClientHandshakeHandler
-
Channel event that is triggered when a new connected channel is created.
- channelActive(ChannelHandlerContext) - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslNettyClient
-
- ChannelImplementation - Enum in org.corfudb.comm
-
An enum representing channel implementation types available to the client.
- ChannelImplementation.EventLoopGroupGenerator - Interface in org.corfudb.comm
-
A functional interface for generating event loops.
- channelInactive(ChannelHandlerContext) - Method in class org.corfudb.infrastructure.ServerHandshakeHandler
-
Channel event that is triggered when the channel is closed.
- channelInactive(ChannelHandlerContext) - Method in class org.corfudb.protocols.wireprotocol.ClientHandshakeHandler
-
Channel event that is triggered when the channel is closed.
- channelRead(ChannelHandlerContext, Object) - Method in class org.corfudb.infrastructure.NettyServerRouter
-
Handle an incoming message read on the channel.
- channelRead(ChannelHandlerContext, Object) - Method in class org.corfudb.infrastructure.ServerHandshakeHandler
-
Read data from the Channel.
- channelRead(ChannelHandlerContext, Object) - Method in class org.corfudb.protocols.wireprotocol.ClientHandshakeHandler
-
Read data from the Channel.
- channelRead(ChannelHandlerContext, Object) - Method in class org.corfudb.protocols.wireprotocol.InboundMsgFilterHandler
-
- channelRead0(ChannelHandlerContext, CorfuMsg) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslNettyServer
-
- check(Spec<T, R>) - Method in class org.corfudb.universe.scenario.Scenario.ScenarioTest
-
Check action result
- check(T, R) - Method in interface org.corfudb.universe.scenario.spec.Spec
-
- checkClientTrusted(X509Certificate[], String) - Method in class org.corfudb.security.tls.ReloadableTrustManager
-
- checkMaxWriteSize(int) - Method in class org.corfudb.protocols.wireprotocol.LogData
-
Verify that max payload is enforced for the specified limit.
- CHECKPOINT_SUFFIX - Static variable in class org.corfudb.runtime.view.StreamsView
-
Checkpoint of streams have their own stream id derived from the
stream id.
- CheckpointEntry - Class in org.corfudb.protocols.logprotocol
-
Object & serialization methods for in-stream checkpoint
summarization of SMR object state.
- CheckpointEntry(CheckpointEntry.CheckpointEntryType, String, UUID, UUID, Map<CheckpointEntry.CheckpointDictKey, String>, MultiSMREntry) - Constructor for class org.corfudb.protocols.logprotocol.CheckpointEntry
-
- CheckpointEntry.CheckpointDictKey - Enum in org.corfudb.protocols.logprotocol
-
- CheckpointEntry.CheckpointEntryType - Enum in org.corfudb.protocols.logprotocol
-
- CheckpointOperation - Class in org.corfudb.generator.operations
-
Created by maithem on 7/14/17.
- CheckpointOperation(State) - Constructor for class org.corfudb.generator.operations.CheckpointOperation
-
- CheckpointWriter<T extends Map> - Class in org.corfudb.runtime
-
Checkpoint writer for SMRMaps: take a snapshot of the
object via TXBegin(), then dump the frozen object's
state into CheckpointEntry records into the object's
stream.
- CheckpointWriter(CorfuRuntime, UUID, String, T) - Constructor for class org.corfudb.runtime.CheckpointWriter
-
Constructor for Checkpoint Writer for Corfu Maps.
- checkServerTrusted(X509Certificate[], String) - Method in class org.corfudb.security.tls.ReloadableTrustManager
-
- checksum - Variable in class org.corfudb.infrastructure.log.AddressMetaData
-
- ClassUtils - Class in org.corfudb.universe.util
-
- cleanAll() - Static method in class org.corfudb.universe.util.IpTablesUtil
-
Clean all rules
- cleanInput() - Static method in class org.corfudb.universe.util.IpTablesUtil
-
Clean all input rules
- cleanOutput() - Static method in class org.corfudb.universe.util.IpTablesUtil
-
Clean all output rules
- cleanShutdown(List<AbstractServer>) - Static method in class org.corfudb.infrastructure.CorfuServer
-
Attempt to cleanly shutdown all the servers.
- cleanup(Consumer<T>) - Method in class org.corfudb.util.concurrent.SingletonResource
-
Note(Maithem): We need to remove this method, it shouldn't be used.
- clear() - Method in class org.corfudb.runtime.collections.CorfuTable
- clear() - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Removes all of the mappings from this map (optional operation).
- clear() - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- clear() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- clearCommit() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- clearUndoRecord() - Method in class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
Clear the undo record for this entry.
- clearUnResponsiveServers() - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Clears the existing unresponsive servers.
- client - Variable in class org.corfudb.universe.scenario.fixture.Fixtures.AbstractUniverseFixture
-
- ClientHandler - Annotation Type in org.corfudb.runtime.clients
-
Registers the method with the annotation as a client response
handler and invokes on reception of message response.
- ClientHandshakeHandler - Class in org.corfudb.protocols.wireprotocol
-
The ClientHandshakeHandler initiates the handshake upon socket connection.
- ClientHandshakeHandler(UUID, UUID, int) - Constructor for class org.corfudb.protocols.wireprotocol.ClientHandshakeHandler
-
Creates a new ClientHandshakeHandler which will handle the handshake between the
current client and a remote server.
- ClientHandshakeHandler.ClientHandshakeEvent - Enum in org.corfudb.protocols.wireprotocol
-
Events that the handshaker sends to downstream handlers.
- clientList - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
The clients registered to this router.
- ClientMsgHandler - Class in org.corfudb.runtime.clients
-
Invokes the message handler to handle incoming messages.
- ClientMsgHandler(IClient) - Constructor for class org.corfudb.runtime.clients.ClientMsgHandler
-
Construct a new instance of ClientMsgHandler.
- ClientMsgHandler.Handler<T extends CorfuMsg> - Interface in org.corfudb.runtime.clients
-
- ClientParams - Class in org.corfudb.universe.node.client
-
- ClientParams() - Constructor for class org.corfudb.universe.node.client.ClientParams
-
- clone(Object, CorfuRuntime) - Method in interface org.corfudb.util.serializer.ISerializer
-
Clone an object through serialization.
- close() - Method in class org.corfudb.infrastructure.BatchProcessor
-
- close() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- close() - Method in interface org.corfudb.infrastructure.log.MultiReadWriteLock.AutoCloseableLock
-
- close() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Close the stream log.
- close() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- close() - Method in class org.corfudb.infrastructure.ServerContext
- close() - Method in class org.corfudb.protocols.wireprotocol.ILogData.SerializationHandle
- close() - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
- close() - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
- close() - Method in class org.corfudb.util.LockUtils.AutoCloseRwLock
-
Closes this resource, relinquishing any underlying resources.
- closestTagCommitCount - Variable in class org.corfudb.util.GitRepositoryState
-
- closestTagName - Variable in class org.corfudb.util.GitRepositoryState
-
- cluster(String, NodeConnectivity...) - Static method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph.ClusterGraphHelper
-
- Cluster - Interface in org.corfudb.universe.group.cluster
-
- ClusterAdvisor - Interface in org.corfudb.infrastructure.management
-
ClusterAdvisor
provides methods to decide the status of Corfu servers
(failed or healed) in a given
Layout
and for a specific view of the cluster
captured in a
ClusterState
.
- ClusterAdvisorFactory - Class in org.corfudb.infrastructure.management
-
- ClusterGraph - Class in org.corfudb.infrastructure.management.failuredetector
-
Graph representation of a cluster state.
- ClusterGraph() - Constructor for class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
- ClusterGraph.ClusterGraphHelper - Class in org.corfudb.infrastructure.management.failuredetector
-
Helper provides methods to build cluster graph
- clusterId - Variable in class org.corfudb.runtime.CorfuRuntime
-
The
UUID
of the cluster we are currently connected to, or null, if
there is no cluster yet.
- ClusterState - Class in org.corfudb.protocols.wireprotocol
-
Records the cluster state of the system.
- ClusterState(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.ClusterState
-
- ClusterStateAggregator - Class in org.corfudb.infrastructure.management
-
Aggregates cluster state from a list of collected states.
- ClusterStateAggregator() - Constructor for class org.corfudb.infrastructure.management.ClusterStateAggregator
-
- ClusterStateCollector - Class in org.corfudb.infrastructure.management
-
Collects information about cluster state.
- ClusterStateCollector() - Constructor for class org.corfudb.infrastructure.management.ClusterStateCollector
-
- ClusterStateContext - Class in org.corfudb.infrastructure.management
-
Cluster State Context maintains shared context composing of cluster connectivity.
- ClusterStateContext() - Constructor for class org.corfudb.infrastructure.management.ClusterStateContext
-
- ClusterStateContext.HeartbeatCounter - Class in org.corfudb.infrastructure.management
-
- ClusterStatusReport - Class in org.corfudb.runtime.view
-
Status report of the connectivity of the client to the cluster and the health of the cluster
based on the views of the management agents on the Corfu nodes.
- ClusterStatusReport() - Constructor for class org.corfudb.runtime.view.ClusterStatusReport
-
- ClusterStatusReport.ClusterStatus - Enum in org.corfudb.runtime.view
-
Health of the cluster.
- ClusterStatusReport.ClusterStatusReliability - Enum in org.corfudb.runtime.view
-
Represents the sources for cluster status computation.
- ClusterStatusReport.ConnectivityStatus - Enum in org.corfudb.runtime.view
-
Represents the connectivity status of this runtime to a node.
- ClusterStatusReport.NodeStatus - Enum in org.corfudb.runtime.view
-
Connectivity to the node.
- ClusterType - Enum in org.corfudb.infrastructure.management
-
ClusterType
is the enumeration of policies each of which representing
specific algorithms for evaluating the cluster and providing recommendation on the failure or
healing status of nodes in a Corfu server cluster.
- collectClusterState(long, SequencerMetrics) - Method in class org.corfudb.infrastructure.management.ClusterStateCollector
-
Provides cluster state
- collectWrongEpochs() - Method in class org.corfudb.infrastructure.management.ClusterStateCollector
-
Provides list of servers containing different epochs to this server.
- commit() - Method in class org.corfudb.security.sasl.plaintext.PlainTextLoginModule
-
- commitAddress - Variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
The address that the transaction was committed at.
- commitId - Variable in class org.corfudb.util.GitRepositoryState
-
- commitIdAbbrev - Variable in class org.corfudb.util.GitRepositoryState
-
- commitMessageFull - Variable in class org.corfudb.util.GitRepositoryState
-
- commitMessageShort - Variable in class org.corfudb.util.GitRepositoryState
-
- committed(long, Layout) - Method in class org.corfudb.runtime.clients.LayoutClient
-
Informs the server that the proposal (layout) has been committed to a quorum.
- committed(long, Layout) - Method in class org.corfudb.runtime.view.LayoutView
-
Send committed layout to the old Layout servers and the new Layout Servers.
- committed(long, Layout, boolean) - Method in class org.corfudb.runtime.view.LayoutView
-
Send committed layout to the old Layout servers and the new Layout Servers.
- commitTime - Variable in class org.corfudb.util.GitRepositoryState
-
- commitTransaction() - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Commit the transaction to the log.
- commitTransaction() - Method in class org.corfudb.runtime.object.transactions.OptimisticTransactionalContext
-
Commit the transaction.
- commitTransaction() - Method in class org.corfudb.runtime.object.transactions.WriteAfterWriteTransactionalContext
-
- commitUserEmail - Variable in class org.corfudb.util.GitRepositoryState
-
- commitUserName - Variable in class org.corfudb.util.GitRepositoryState
-
- compact() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- compact() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Remove all trimmed addresses from the StreamLog.
- compact() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- compact() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Send a compact request that will delete the trimmed parts of the log.
- compareTo(NodeConnectivity) - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity
-
Compare node connectivity's according to their endpoints
- compareTo(NodeRank) - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeRank
-
Comparator, sorting nodes according to their number of connections and alphabetically
- compareTo(ILogData) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- compareTo(IMetadata.DataRank) - Method in class org.corfudb.protocols.wireprotocol.IMetadata.DataRank
-
- compareTo(NodeState.HeartbeatTimestamp) - Method in class org.corfudb.protocols.wireprotocol.NodeState.HeartbeatTimestamp
-
- compareTo(Token) - Method in class org.corfudb.protocols.wireprotocol.Token
-
- compareTo(AbstractTransactionalContext) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Transactions are ordered by their snapshot timestamp.
- compareTo(AbstractStreamContext) - Method in class org.corfudb.runtime.view.stream.AbstractStreamContext
- compareTo(ClientParams) - Method in class org.corfudb.universe.node.client.ClientParams
-
- compareTo(CorfuServer) - Method in class org.corfudb.universe.node.server.AbstractCorfuServer
-
- compareTo(CorfuServerParams) - Method in class org.corfudb.universe.node.server.CorfuServerParams
-
- completed() - Method in interface org.corfudb.infrastructure.orchestrator.IWorkflow
-
Returns whether all the actions completed successfully or not.
- completed() - Method in class org.corfudb.protocols.wireprotocol.HandshakeState
-
Get Handshake Completeness State
- completeExceptionally(long, Throwable) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Exceptionally complete a request with a given cause.
- completeExceptionally(long, Throwable) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Exceptionally complete a request with a given cause.
- CompleteGraphAdvisor - Class in org.corfudb.infrastructure.management
-
This class is an implementation of
ClusterType
where the ideal state
of the Corfu cluster is a fully connected network (i.e.
- CompleteGraphAdvisor(String) - Constructor for class org.corfudb.infrastructure.management.CompleteGraphAdvisor
-
- completeRequest(long, T) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Complete a given outstanding request with a completion value.
- completeRequest(long, T) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Complete a given outstanding request with a completion value.
- completionFuture - Variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
A future which gets completed when this transaction commits.
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Attempts to compute a mapping for the specified key and its current
mapped value (or null
if there is no current mapping).
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.corfudb.runtime.collections.CorfuTable
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
If the specified key is not already associated with a value (or is mapped
to null
), attempts to compute its value using the given mapping
function and enters it into this map unless null
.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.CorfuTable
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
If the value for the specified key is present and non-null, attempts to
compute a new mapping given the key and its current mapped value.
- Config() - Constructor for class org.corfudb.infrastructure.SequencerServer.Config
-
- configure(ServerBootstrap) - Method in interface org.corfudb.infrastructure.CorfuServer.BootstrapConfigurer
-
Configure a ServerBootstrap
.
- configureBootstrapOptions(ServerContext, ServerBootstrap) - Static method in class org.corfudb.infrastructure.CorfuServer
-
Configure server bootstrap per-channel options, such as TCP options, etc.
- ConflictParameter - Annotation Type in org.corfudb.annotations
-
This annotation marks that a parameter should be considered
to generate the hash for fine-grained conflict resolution.
- conflicts - Variable in class org.corfudb.runtime.object.transactions.ConflictSetInfo
-
Set of objects this conflict set conflicts with.
- ConflictSetInfo - Class in org.corfudb.runtime.object.transactions
-
This class captures information about objects accessed (read) during speculative
transaction execution.
- ConflictSetInfo() - Constructor for class org.corfudb.runtime.object.transactions.ConflictSetInfo
-
- ConflictTxStream(UUID, byte[]) - Constructor for class org.corfudb.infrastructure.SequencerServerCache.ConflictTxStream
-
- connect() - Method in class org.corfudb.runtime.CorfuRuntime
-
Connect to the Corfu server instance.
- connect() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
- connect() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- connectivity(String, ImmutableMap<String, NodeConnectivity.ConnectionStatus>) - Static method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity
-
Factory method to build a node connectivity
- connectivityGraph() - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Transform ClusterGraph to Connectivity graph
- ConnectivityGraph(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.failuredetector.FailureDetectorMetrics.ConnectivityGraph
-
- ConservativeFailureHandlerPolicy - Class in org.corfudb.runtime.view
-
Conserves the failures.
- ConservativeFailureHandlerPolicy() - Constructor for class org.corfudb.runtime.view.ConservativeFailureHandlerPolicy
-
- construct(ByteBuf) - Method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload.PayloadConstructor
-
- constructorMap - Static variable in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
- ConstructorType - Enum in org.corfudb.annotations
-
An enumeration which describes whether the arguments to
the constructor should be persisted on the log or only
applied at runtime to the state of the object.
- constructSslContext(boolean, String, String, String, String) - Static method in class org.corfudb.security.tls.SslContextConstructor
-
Create SslContext object based on a spec of individual configuration strings.
- contains(Object) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- containsAll(Collection<?>) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- containsKey(Object) - Method in class org.corfudb.runtime.collections.CorfuTable
- containsKey(Object) - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- containsStream(UUID) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Get whether or not this entry contains a given stream.
- containsThrowableFrom(Class<? extends Throwable>) - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
Checks whether one of the exceptions is throwable from the given type.
- containsValue(Object) - Method in class org.corfudb.runtime.collections.CorfuTable
- containsValue(Object) - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Returns true if this map maps one or more keys to the
specified value.
- containsValue(Object) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- convertToByteStringRepresentation(long) - Static method in class org.corfudb.util.Utils
-
Convert to byte string representation.
- copyAddressesToSet(Long) - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Copy this stream's addresses to a set, under a given boundary (inclusive).
- copyBaseFields(CorfuMsg) - Method in class org.corfudb.protocols.wireprotocol.CorfuMsg
-
Copy the base fields over to this message.
- copyFile(String, String, String, String, String) - Method in class org.corfudb.universe.group.cluster.vm.RemoteOperationHelper
-
Copy a file from local computer to a remote computer
- copyManagementLayout() - Method in class org.corfudb.infrastructure.ServerContext
-
Fetches and creates a copy of the Management Layout from the local datastore.
- CORFU - Static variable in class org.corfudb.util.serializer.Serializers
-
- CorfuClient - Interface in org.corfudb.universe.node.client
-
Represent a Corfu client implementation of
Node
.
- CorfuCluster - Interface in org.corfudb.universe.group.cluster
-
Provides a Corfu specific cluster of servers
- corfuCluster - Variable in class org.corfudb.universe.scenario.fixture.Fixtures.AbstractUniverseFixture
-
- CorfuClusterParams - Class in org.corfudb.universe.group.cluster
-
- CorfuClusterParams() - Constructor for class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- CorfuCompileProxy<T> - Class in org.corfudb.runtime.object
-
In the Corfu runtime, on top of a stream,
an SMR object layer implements objects whose history of updates
are backed by a stream.
- CorfuCompileProxy(CorfuRuntime, UUID, Class<T>, Object[], ISerializer, Map<String, ICorfuSMRUpcallTarget<T>>, Map<String, IUndoFunction<T>>, Map<String, IUndoRecordFunction<T>>, Set<String>) - Constructor for class org.corfudb.runtime.object.CorfuCompileProxy
-
Deprecated.
- CorfuCompileWrapperBuilder - Class in org.corfudb.runtime.object
-
Builds a wrapper for the underlying SMR Object.
- CorfuCompileWrapperBuilder() - Constructor for class org.corfudb.runtime.object.CorfuCompileWrapperBuilder
-
- CorfuComponent - Enum in org.corfudb.util
-
An enum used to hold the corfu component names and is used to name metrics
collected from different components.
- CorfuCompoundObject - Class in org.corfudb.samples
-
Corfu objects may be compound, and work as expected.
- CorfuCompoundObject() - Constructor for class org.corfudb.samples.CorfuCompoundObject
-
- CorfuCompoundObject.Inner - Class in org.corfudb.samples
-
- CorfuMsg - Class in org.corfudb.protocols.wireprotocol
-
Created by mwei on 9/15/15.
- CorfuMsg(CorfuMsgType) - Constructor for class org.corfudb.protocols.wireprotocol.CorfuMsg
-
Constructor which generates a message based only the message type.
- CorfuMsgHandler - Class in org.corfudb.infrastructure
-
This class implements message handlers for
AbstractServer
implementations.
- CorfuMsgHandler() - Constructor for class org.corfudb.infrastructure.CorfuMsgHandler
-
Construct a new instance of CorfuMsgHandler.
- CorfuMsgType - Enum in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/8/16.
- CorfuObject - Annotation Type in org.corfudb.annotations
-
Marks an object which should exist in the Corfu log.
- CorfuPayload - Annotation Type in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/8/16.
- CorfuPayloadMsg<T> - Class in org.corfudb.protocols.wireprotocol
-
A message type which represents an encapsulated Corfu
payload.
- CorfuPayloadMsg(CorfuMsgType, T) - Constructor for class org.corfudb.protocols.wireprotocol.CorfuPayloadMsg
-
- CorfuRuntime - Class in org.corfudb.runtime
-
Created by mwei on 12/9/15.
- CorfuRuntime() - Constructor for class org.corfudb.runtime.CorfuRuntime
-
- CorfuRuntime(String) - Constructor for class org.corfudb.runtime.CorfuRuntime
-
- CorfuRuntime.CorfuRuntimeParameters - Class in org.corfudb.runtime
-
A class which holds parameters and settings for the
CorfuRuntime
.
- CorfuRuntimeParameters() - Constructor for class org.corfudb.runtime.CorfuRuntime.CorfuRuntimeParameters
-
- CorfuSerializer - Class in org.corfudb.util.serializer
-
Created by mwei on 9/29/15.
- CorfuSerializer(byte) - Constructor for class org.corfudb.util.serializer.CorfuSerializer
-
- CorfuServer - Class in org.corfudb.infrastructure
-
This is the new Corfu server single-process executable.
- CorfuServer() - Constructor for class org.corfudb.infrastructure.CorfuServer
-
- CorfuServer - Interface in org.corfudb.universe.node.server
-
Represent a Corfu server implementation of
Node
used in the
Universe
.
- CorfuServer.BootstrapConfigurer - Interface in org.corfudb.infrastructure
-
A functional interface for receiving and configuring a ServerBootstrap
.
- CorfuServer.Mode - Enum in org.corfudb.universe.node.server
-
- CorfuServer.Persistence - Enum in org.corfudb.universe.node.server
-
- CorfuServerParams - Class in org.corfudb.universe.node.server
-
- CorfuServerParams() - Constructor for class org.corfudb.universe.node.server.CorfuServerParams
-
- CorfuSharedCounter - Class in org.corfudb.samples
-
The annotation @CorfuObject turns this into a Corfu object
- CorfuSharedCounter() - Constructor for class org.corfudb.samples.CorfuSharedCounter
-
- CORFUSMR_SUFFIX - Static variable in interface org.corfudb.runtime.object.ICorfuSMR
-
The suffix for all precompiled SMR wrapper classes.
- CorfuTable<K,V> - Class in org.corfudb.runtime.collections
-
The CorfuTable implements a simple key-value store.
- CorfuTable(CorfuTable.IndexRegistry<K, V>) - Constructor for class org.corfudb.runtime.collections.CorfuTable
-
Generate a table with the given set of indexes.
- CorfuTable() - Constructor for class org.corfudb.runtime.collections.CorfuTable
-
Default constructor.
- CorfuTable.Index<K,V,I extends Comparable<?>> - Class in org.corfudb.runtime.collections
-
Descriptor of named indexing function entry.
- CorfuTable.IndexFunction<K,V,I extends Comparable<?>> - Interface in org.corfudb.runtime.collections
-
Denotes a function that takes as input the key and value of an
CorfuTable
record, and computes the associated index value for the record.
- CorfuTable.IndexName - Interface in org.corfudb.runtime.collections
-
Denotes a function that supplies the unique name of an index registered to
CorfuTable
.
- CorfuTable.IndexRegistry<K,V> - Interface in org.corfudb.runtime.collections
-
- CorfuTable.IndexSpecification<K,V,I extends Comparable<?>,P> - Interface in org.corfudb.runtime.collections
-
The interface for a index specification, which consists of a indexing function
and a projection function.
- CorfuTable.MultiValueIndexFunction<K,V,I extends Comparable<?>> - Interface in org.corfudb.runtime.collections
-
- CorfuTable.ProjectionFunction<K,V,I,P> - Interface in org.corfudb.runtime.collections
-
The interface for a projection function.
- Correctness - Class in org.corfudb.generator
-
Created by rmichoud on 10/9/17.
- COW_BACKPOINTER - Static variable in class org.corfudb.runtime.view.Address
-
Indicates that the previous entry in the stream belongs
to another stream.
- createDefaultCorfuTable(String) - Method in interface org.corfudb.universe.node.client.CorfuClient
-
Create a default CorfuTable object for data-path
verification in scenario tests
- createDefaultCorfuTable(String) - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- createForStrategy(ClusterType, String) - Static method in class org.corfudb.infrastructure.management.ClusterAdvisorFactory
-
- CreateRequest - Interface in org.corfudb.protocols.wireprotocol.orchestrator
-
All requests that create workflows should implement this interface.
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer.PlainTextSaslServerFactory
-
- CreateWorkflowResponse - Class in org.corfudb.protocols.wireprotocol.orchestrator
-
CreateWorkflowResponse returns the UUID of a created workflow.
- CreateWorkflowResponse(UUID) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.CreateWorkflowResponse
-
- CreateWorkflowResponse(byte[]) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.CreateWorkflowResponse
-
- current() - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- current() - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
Returns the list of SMREntries positioned at the current global log.
- current() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- current() - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Retrieve the current entry in the stream, which was the entry previously
returned by a call to next() or previous().
- current() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Retrieve the current entry in the stream, which was the entry previously
returned by a call to next() or previous().
- current() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- customHashingMap - Static variable in interface org.corfudb.util.serializer.ISerializer
-
- failAfter(Duration) - Static method in class org.corfudb.util.CFUtils
-
Generates a completable future which times out.
- failed() - Method in class org.corfudb.protocols.wireprotocol.HandshakeState
-
Get Handshake Failure State
- failedServer(ClusterState, List<String>) - Method in interface org.corfudb.infrastructure.management.ClusterAdvisor
-
Provide a list of servers in the Corfu cluster which according to the underlying algorithm
for
ClusterType
have failed.
- failedServer(ClusterState, List<String>) - Method in class org.corfudb.infrastructure.management.CompleteGraphAdvisor
-
Provides list of servers from a given layout(epoch) that this implementation of
COMPLETE_GRAPH algorithm has determined as failed.
- FailureDetector - Class in org.corfudb.infrastructure.management
-
FailureDetector polls all the "responsive members" in the layout.
- FailureDetector(ClusterStateContext.HeartbeatCounter, String) - Constructor for class org.corfudb.infrastructure.management.FailureDetector
-
- FailureDetectorMetrics - Class in org.corfudb.protocols.wireprotocol.failuredetector
-
Full information about failure that changed cluster state.
- FailureDetectorMetrics(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.failuredetector.FailureDetectorMetrics
-
- FailureDetectorMetrics.ConnectivityGraph - Class in org.corfudb.protocols.wireprotocol.failuredetector
-
Simplified version of a ClusterGraph, contains only connectivity information.
- FailureDetectorMetrics.FailureDetectorAction - Enum in org.corfudb.protocols.wireprotocol.failuredetector
-
- FakeDns - Class in org.corfudb.universe.universe.docker
-
Fake DNS resolver which allows our tests to work well even though we use
strange loopback IP addresses (127.x.y.z) with no corresponding reverse
DNS.
- FastObjectLoader - Class in org.corfudb.recovery
-
The FastObjectLoader reconstructs the coalesced state of SMRMaps through sequential log read
This utility reads Log entries sequentially extracting the SMRUpdates from each entry
and build the Maps as we go.
- FastObjectLoader(CorfuRuntime) - Constructor for class org.corfudb.recovery.FastObjectLoader
-
- FastObjectLoader.BoundedQueue<E> - Class in org.corfudb.recovery
-
This queue implementation is to be used by single threaded exeuctors
to restrict the amount of pending job submissions.
- FastObjectLoaderException - Exception in org.corfudb.runtime.exceptions
-
Thrown when the fast loader encounters an exception.
- FastObjectLoaderException(String) - Constructor for exception org.corfudb.runtime.exceptions.FastObjectLoaderException
-
- fetch(long) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Explicitly fetch a given address, bypassing the cache.
- fetchAll(Iterable<Long>, boolean) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Fetch a collection of addresses for insertion into the cache.
- FGMap<K,V> - Class in org.corfudb.runtime.collections
-
Deprecated.
- FGMap(int) - Constructor for class org.corfudb.runtime.collections.FGMap
-
Deprecated.
- FGMap() - Constructor for class org.corfudb.runtime.collections.FGMap
-
Deprecated.
- fillFromResolved(long, AbstractQueuedStreamView.QueuedStreamContext) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
- fillHole(Token) - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Fill a hole at a given address.
- FillHoleRequest - Class in org.corfudb.protocols.wireprotocol
-
Request sent to fill a hole.
- FillHoleRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.FillHoleRequest
-
Constructor to generate a Fill Hole Request Payload.
- fillReadQueue(long, AbstractQueuedStreamView.QueuedStreamContext) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Fill the read queue for the current context.
- find(long, IStreamView.SearchDirection) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Find the global address of the next entry in this stream,
in the direction given.
- find(long, IStreamView.SearchDirection) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Find the global address of the next entry in this stream,
in the direction given.
- find(long, IStreamView.SearchDirection) - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- findFailedNode() - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Find failed node in a graph.
- findFullyConnectedNode(String, List<String>) - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
See if the node is fully connected.
- finishCheckpoint() - Method in class org.corfudb.runtime.CheckpointWriter
-
Append a checkpoint END record to this object's stream.
- Fixture<T> - Interface in org.corfudb.universe.scenario.fixture
-
Fixture - shared test context, provides input data for tests.
- Fixtures - Interface in org.corfudb.universe.scenario.fixture
-
Fixture factory provides predefined fixtures
- Fixtures.AbstractUniverseFixture<T extends UniverseParams> - Class in org.corfudb.universe.scenario.fixture
-
- Fixtures.FixtureUtil - Class in org.corfudb.universe.scenario.fixture
-
- Fixtures.TestFixtureConst - Class in org.corfudb.universe.scenario.fixture
-
Common constants used for test
- Fixtures.UniverseFixture - Class in org.corfudb.universe.scenario.fixture
-
Common configuration for Universe initialization
- Fixtures.VmUniverseFixture - Class in org.corfudb.universe.scenario.fixture
-
Configuration for VM specific Universe initialization
- flushCache() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Send a flush cache request that will flush the logunit cache.
- FOLDED_ADDRESS - Static variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Constant for a transaction which has been folded into
another transaction.
- force(Layout) - Method in class org.corfudb.runtime.clients.LayoutClient
-
Send a force commit layout request to a layout server
- forceLayout(Layout, Layout) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Attempts to force commit a new layout to the cluster.
- forceRemoveNode(String) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Send a force remove node request to an orchestrator service node.
- forceRemoveNode(String, int, Duration, Duration) - Method in class org.corfudb.runtime.view.ManagementView
-
Force remove a node from the cluster.
- ForceRemoveNode - Class in org.corfudb.runtime.view.workflows
-
A workflow request that makes an orchestrator call to force remove a node from
the cluster.
- ForceRemoveNode(String, CorfuRuntime, int, Duration, Duration) - Constructor for class org.corfudb.runtime.view.workflows.ForceRemoveNode
-
- ForceRemoveNodeRequest - Class in org.corfudb.protocols.wireprotocol.orchestrator
-
A request to force remove an endpoint from the cluster.
- ForceRemoveNodeRequest(String) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.ForceRemoveNodeRequest
-
Create a force remove request.
- ForceRemoveNodeRequest(byte[]) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.ForceRemoveNodeRequest
-
Create a force remove request from a byte array.
- ForceRemoveWorkflow - Class in org.corfudb.infrastructure.orchestrator.workflows
-
This workflow removes an endpoint from the cluster forcefully by bypassing consensus.
- ForceRemoveWorkflow(ForceRemoveNodeRequest) - Constructor for class org.corfudb.infrastructure.orchestrator.workflows.ForceRemoveWorkflow
-
Create this workflow from a force remove request.
- forEach(BiConsumer<? super K, ? super V>) - Method in class org.corfudb.runtime.collections.CorfuTable
- forEach(BiConsumer<? super K, ? super V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Performs the given action for each entry in this map until all entries
have been processed or the action throws an exception.
- forEach(Consumer<? super E>) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- fromBase64(String) - Static method in class org.corfudb.util.UuidUtils
-
Generate a UUID from a base64 URL-safe string.
- fromBool(boolean) - Static method in enum org.corfudb.infrastructure.RemoteMonitoringService.DetectorTask
-
- fromBool(boolean) - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity.ConnectionStatus
-
- fromBuffer(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.CorfuMsg
-
Parse the rest of the message from the buffer.
- fromBuffer(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.CorfuPayloadMsg
-
Parse the rest of the message from the buffer.
- fromBuffer(ByteBuf, Class<T>) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
Build payload from Buffer
- fromBuffer(ByteBuf, TypeToken<T>) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
Build payload from Buffer.
- fromBuffer(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.JSONPayloadMsg
-
Parse the rest of the message from the buffer.
- fromBuffer(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.LayoutMsg
-
Parse the rest of the message from the buffer.
- fromId(int) - Static method in enum org.corfudb.runtime.exceptions.OverwriteCause
-
- fromJSONString(String) - Static method in class org.corfudb.runtime.view.Layout
-
Get a layout from a JSON string.
- fromParameters(CorfuRuntime.CorfuRuntimeParameters) - Static method in class org.corfudb.runtime.CorfuRuntime
-
- gc(long) - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- gc(long) - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- gc(long) - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- gc(long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Run gc on this object.
- gc(long) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Remove all log entries that are less than the trim mark
- gc() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Force compaction on an address space, which will force
all log units to free space, and process any outstanding
trim requests.
- gc(long) - Method in class org.corfudb.runtime.view.ObjectsView
-
Run garbage collection on all opened objects.
- gc(long) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
- gc(long) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Garbage collect all the trimmed entries on this stream
- gc(long) - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- gc(long) - Method in class org.corfudb.runtime.view.StreamsView
-
Run garbage collection on all opened streams.
- gcTrimMark - Variable in class org.corfudb.runtime.view.stream.AbstractStreamContext
-
The trim mark for Garbage Collection.
- generate(int, ThreadFactory) - Method in interface org.corfudb.comm.ChannelImplementation.EventLoopGroupGenerator
-
- generateCorfuHash() - Method in interface org.corfudb.util.serializer.ICorfuHashable
-
Generate a hash for this object to be used by Corfu.
- generateHandler(MethodHandles.Lookup, AbstractServer) - Static method in class org.corfudb.infrastructure.CorfuMsgHandler
-
Generate handlers for a particular server.
- generateHandlers(MethodHandles.Lookup, Object) - Method in class org.corfudb.runtime.clients.ClientMsgHandler
-
Generate handlers for a particular client.
- generateHashFromObject(ICorfuSMRProxyInternal, Object) - Static method in class org.corfudb.runtime.object.transactions.ConflictSetInfo
-
Get a hash for the object, given a proxy.
- generateLayout(Layout, CorfuRuntime, Set<String>, Set<String>) - Method in class org.corfudb.runtime.view.ConservativeFailureHandlerPolicy
-
Modifies the layout by marking the failed nodes as unresponsive but still keeping them in
the layout and sequencer servers lists.
- generateLayout(Layout, CorfuRuntime, Set<String>, Set<String>) - Method in interface org.corfudb.runtime.view.IFailureHandlerPolicy
-
Generates a new layout based on the set of failures.
- generateLayout(Layout, CorfuRuntime, Set<String>, Set<String>) - Method in interface org.corfudb.runtime.view.IReconfigurationHandlerPolicy
-
Generates a new layout based on the set of failures.
- generateProjection(I, Stream<Map.Entry<K, V>>) - Method in interface org.corfudb.runtime.collections.CorfuTable.ProjectionFunction
-
- generateProxy(TypeElement) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
-
Generate a proxy file.
- Generator - Class in org.corfudb.generator
-
Generator is a program that generates synthetic workloads that try to mimic
real applications that consume the CorfuDb client.
- Generator() - Constructor for class org.corfudb.generator.Generator
-
- get(CorfuTable.IndexName) - Method in class org.corfudb.generator.StringIndexer
-
- get(Class<T>, String, String) - Method in class org.corfudb.infrastructure.DataStore
-
- get(IDataStore.KvRecord<T>) - Method in class org.corfudb.infrastructure.DataStore
-
- get(IDataStore.KvRecord<T>, T) - Method in class org.corfudb.infrastructure.DataStore
-
- get(Class<T>, String, String) - Method in interface org.corfudb.infrastructure.IDataStore
-
Deprecated.
- get(IDataStore.KvRecord<T>) - Method in interface org.corfudb.infrastructure.IDataStore
-
Retrieves the value for a key under a prefix.
- get(IDataStore.KvRecord<T>, T) - Method in interface org.corfudb.infrastructure.IDataStore
-
Retrieves the value for a key or a default value
- get() - Method in class org.corfudb.infrastructure.management.ClusterStateContext.HeartbeatCounter
-
- get(Object) - Method in class org.corfudb.runtime.collections.CorfuTable
- get(CorfuTable.IndexName) - Method in interface org.corfudb.runtime.collections.CorfuTable.IndexRegistry
-
- get(Object) - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Returns the value to which the specified key is mapped,
or null
if this map contains no mapping for the key.
- get(Object) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- get(long, TimeUnit) - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
- get() - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
- get(UUID) - Method in class org.corfudb.runtime.view.StreamsView
-
Get a view on a stream.
- get(UUID, StreamOptions) - Method in class org.corfudb.runtime.view.StreamsView
-
Get a view on a stream.
- Get() - Method in class org.corfudb.samples.CorfuSharedCounter
-
Get() method is annotates as an Accessor method.
- get() - Method in class org.corfudb.util.concurrent.SingletonResource
-
Get the resource, potentially generating it by calling the generator
if necessary.
- getAcceptedIssuers() - Method in class org.corfudb.security.tls.ReloadableTrustManager
-
- getActions() - Method in interface org.corfudb.infrastructure.orchestrator.IWorkflow
-
Returns the ordered that are associated with
this workflow.
- getActiveLayoutServers() - Method in class org.corfudb.runtime.view.Layout
-
- getAddressesInRange(StreamAddressRange) - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Get addresses in range (end, start], where start > end.
- getAddressFromInterfaceName(String) - Static method in class org.corfudb.util.NetworkUtils
-
Fetches the IP address given an interface name.
- getAddressMap() - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
- getAggregatedState() - Method in class org.corfudb.infrastructure.management.ClusterStateAggregator
-
Aggregates state from a list of poll reports.
- getAllActiveServers() - Method in class org.corfudb.runtime.view.Layout
-
This function returns a set of all active servers in the layout.
- getAllLogServers() - Method in class org.corfudb.runtime.view.Layout.LayoutSegment
-
Get all servers from all stripes present in this segment.
- getAllReachableNodes() - Method in class org.corfudb.infrastructure.management.PollReport
-
Returns all connected nodes to the current node including nodes with higher epoch.
- getAllServers() - Method in class org.corfudb.runtime.view.Layout
-
This function returns a set of all servers in the layout.
- getAllTails() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- getAllTails() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Get global and all stream tails.
- getAllTails() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- getAllTails() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Get all stream tails (i.e., maximum address written to every stream) and global tail.
- getAllTails() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Get all tails, includes: log tail and stream tails.
- getAllTails(Layout, CorfuRuntime) - Static method in class org.corfudb.util.Utils
-
Fetches the max global log tail and all stream tails from the log unit cluster.
- getAppVersion() - Static method in class org.corfudb.universe.node.server.AbstractCorfuServer
-
Provides a current version of this project.
- getArgumentTypesFromArgumentList(Object[]) - Static method in class org.corfudb.util.ReflectionUtils
-
Extract argument types from a string that represents the method
signature.
- getArgumentTypesFromString(String) - Static method in class org.corfudb.util.ReflectionUtils
-
Get arguments from method signature.
- getAuthorizationID() - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer
-
- getBackpointer(UUID) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return the backpointer for a particular stream.
- getBackpointerMap() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getBackpointerMap() - Method in interface org.corfudb.protocols.wireprotocol.IToken
-
Get the backpointer map, if it was available.
- getBaseClient(String) - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getBuilder() - Method in class org.corfudb.runtime.object.AbstractCorfuWrapper
-
Get a builder, which allows the construction of
new Corfu objects.
- getByIndex(CorfuTable.IndexName, I) - Method in class org.corfudb.runtime.collections.CorfuTable
-
Get a mapping using the specified index function.
- getByIndexAndFilter(CorfuTable.IndexName, Predicate<? super Map.Entry<K, V>>, I) - Method in class org.corfudb.runtime.collections.CorfuTable
-
Scan and filter using the specified index function and projection.
- getCheckpointedStreamId() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getCheckpointedStreamStartLogAddress() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Returns the tail of the checkpointed stream at the time of taking the checkpoint snapshot.
- getCheckpointId() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getCheckpointStreamIdFromId(UUID) - Static method in class org.corfudb.runtime.CorfuRuntime
-
- getCheckpointStreamIdFromName(String) - Static method in class org.corfudb.runtime.CorfuRuntime
-
- getCheckpointType() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Get checkpoint type.
- getChecksum(byte[]) - Static method in class org.corfudb.infrastructure.DataStore
-
- getChecksum(byte[]) - Static method in class org.corfudb.infrastructure.log.StreamLogFiles.Checksum
-
Returns checksum used for log.
- getChecksum(int) - Static method in class org.corfudb.infrastructure.log.StreamLogFiles.Checksum
-
- getClassFromMethodToString(String) - Static method in class org.corfudb.util.ReflectionUtils
-
Extract class name from method to string path.
- getClient(Class<T>) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Gets a client that matches a particular type.
- getClient(long) - Method in interface org.corfudb.runtime.clients.IHandler
-
Fetches the sender client.
- getClient(long) - Method in class org.corfudb.runtime.clients.LayoutHandler
-
- getClient(long) - Method in class org.corfudb.runtime.clients.LogUnitHandler
-
- getClient(long) - Method in class org.corfudb.runtime.clients.ManagementHandler
-
- getClient(Class<T>) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Gets a client that matches a particular type.
- getClient(long) - Method in class org.corfudb.runtime.clients.SequencerHandler
-
- getClientId() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getClusterHealthForSegment(Layout.LayoutSegment, Set<String>) - Method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
Returns the health of the cluster for a given segment.
- getClusterLayoutServers() - Method in class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
- getClusterLayoutServers() - Method in class org.corfudb.universe.group.cluster.docker.DockerCorfuCluster
-
- getClusterLayoutServers() - Method in class org.corfudb.universe.group.cluster.vm.VmCorfuCluster
-
- getClusterNodes() - Method in class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- getClusterStatus() - Method in class org.corfudb.runtime.view.ManagementView
-
Get the Cluster Status.
- getClusterView() - Method in class org.corfudb.infrastructure.management.ClusterStateContext
-
Returns current cluster state.
- getCommandLineParams() - Method in class org.corfudb.universe.node.server.AbstractCorfuServer
-
This method creates a command line string for starting Corfu server
- getComparator() - Method in class org.corfudb.runtime.view.stream.StreamSpliterator
- getComponentType() - Method in interface org.corfudb.protocols.wireprotocol.ITypedEnum
-
- getConditionalContext(Timer) - Static method in class org.corfudb.util.MetricsUtils
-
- getConditionalContext(boolean, Timer) - Static method in class org.corfudb.util.MetricsUtils
-
- getConflictSet(Object...) - Method in interface org.corfudb.runtime.object.IConflictFunction
-
Given the parameters to a function, getConflictSet the conflict set.
- getConflictSetAndCommit(ConflictSetInfo) - Method in class org.corfudb.runtime.object.transactions.OptimisticTransactionalContext
-
Commit with a given conflict set and return the address.
- getConnected() - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity
-
Get number of nodes this node is connected to
- getConnectedNodes() - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity
-
Contains list of servers successfully connected with current node.
- getConnectionStatus(String) - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity
-
Returns node status: connected, disconnected
- getCorfuResetSet() - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Get a set of strings (function names) which result in a reset
of the object.
- getCorfuRuntime() - Method in class org.corfudb.infrastructure.ManagementAgent
-
Returns a connected instance of the CorfuRuntime.
- getCorfuSMRProxy() - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Get the proxy for this wrapper, to manage the state of the object.
- getCorfuSMRUpcallMap() - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Get a map from strings (function names) to SMR upcalls.
- getCorfuStreamID() - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Return the stream ID that this object belongs to.
- getCorfuUndoMap() - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Get a map from strings (function names) to undo methods.
- getCorfuUndoRecordMap() - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Get a map from strings (function names) to undoRecord methods.
- getCurrentContext() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Returns the current transactional context for the calling thread.
- getCurrentContext() - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Get the current context.
- getCurrentGlobalPosition() - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Get the current position of the pointer in this stream (global address).
- getCurrentGlobalPosition() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Get the current position of the pointer in this stream (global address).
- getCurrentGlobalPosition() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- getCurrentLayout() - Method in class org.corfudb.infrastructure.LayoutServer
-
- getCurrentLayout() - Method in class org.corfudb.infrastructure.ServerContext
-
- getCurrentLayout() - Method in class org.corfudb.runtime.view.AbstractView
-
Get the current layout.
- getCustomHasher(Class<T>) - Method in interface org.corfudb.util.serializer.ISerializer
-
Get a custom hasher from the serializer.
- getDataCache() - Method in class org.corfudb.infrastructure.LogUnitServer
-
- getDataSet() - Method in interface org.corfudb.generator.distributions.DataSet
-
Return the whole data set.
- getDataSet() - Method in class org.corfudb.generator.distributions.Keys
-
- getDataSet() - Method in class org.corfudb.generator.distributions.OperationCount
-
- getDataSet() - Method in class org.corfudb.generator.distributions.Operations
-
- getDataSet() - Method in class org.corfudb.generator.distributions.Streams
-
- getDecisionMaker() - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Get a decision maker node to detect a failure.
- getDefaultRuntimeParameters() - Method in class org.corfudb.infrastructure.ServerContext
-
- getEmpty(long) - Static method in class org.corfudb.protocols.wireprotocol.LogData
-
- getEndpoint() - Method in interface org.corfudb.protocols.wireprotocol.orchestrator.CreateRequest
-
The endpoint of the node to operate on (i.e.
- getEndpoint() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- getEpoch() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Get Log's epoch.
- getEpoch() - Method in interface org.corfudb.protocols.wireprotocol.IToken
-
Get the epoch of the token, which represents the epoch the
token is valid in.
- getEpoch() - Method in class org.corfudb.protocols.wireprotocol.TokenResponse
-
- getExecutor() - Method in class org.corfudb.infrastructure.AbstractServer
-
- getExecutor() - Method in class org.corfudb.infrastructure.BaseServer
-
- getExecutor() - Method in class org.corfudb.infrastructure.LayoutServer
-
- getExecutor() - Method in class org.corfudb.infrastructure.LogUnitServer
-
- getExecutor() - Method in class org.corfudb.infrastructure.ManagementServer
-
- getExecutor() - Method in class org.corfudb.infrastructure.SequencerServer
-
- getFailedNodes() - Method in class org.corfudb.infrastructure.management.PollReport
-
Contains list of servers disconnected from this node.
- getFailedNodes() - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity
-
Contains list of servers disconnected from this node.
- getFailureDetectorMetrics() - Method in class org.corfudb.infrastructure.ServerContext
-
Get latest change in a cluster state saved in data store.
- getFirstSegment() - Method in class org.corfudb.runtime.view.Layout
-
Get the first segment.
- getFirstServer() - Method in interface org.corfudb.universe.group.cluster.CorfuCluster
-
To find the first corfu server in a cluster:
- get all corfu servers in the cluster
- extract first element in the list
- getFirstStripe() - Method in class org.corfudb.runtime.view.Layout.LayoutSegment
-
Gets the first stripe.
- getFixtureData() - Method in class org.corfudb.universe.scenario.Scenario
-
- getFullKeyName() - Method in class org.corfudb.infrastructure.IDataStore.KvRecord
-
- getFullNodeName(String) - Method in class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- getGlobalAddress() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Get Log's global address (global tail).
- getGlobalAddress(Layout.LayoutStripe, long) - Method in class org.corfudb.runtime.view.Layout
-
Return global address for a given stripe.
- getGraph(ClusterState) - Method in interface org.corfudb.infrastructure.management.ClusterAdvisor
-
- getGraph(ClusterState) - Method in class org.corfudb.infrastructure.management.CompleteGraphAdvisor
-
Returns a new cluster graph from the cluster state
- getGroup(String) - Method in class org.corfudb.universe.universe.AbstractUniverse
-
- getGroup(String) - Method in class org.corfudb.universe.universe.process.ProcessUniverse
-
- getGroup(String) - Method in interface org.corfudb.universe.universe.Universe
-
- getGroupParams(String, Class<T>) - Method in class org.corfudb.universe.universe.UniverseParams
-
Returns the configuration of a particular service by the name
- getGroups() - Method in class org.corfudb.universe.universe.UniverseParams
-
- getHandledTypes() - Method in class org.corfudb.infrastructure.CorfuMsgHandler
-
Get the types this handler will handle.
- getHandledTypes() - Method in class org.corfudb.runtime.clients.ClientMsgHandler
-
Get the types this handler will handle.
- getHandledTypes() - Method in interface org.corfudb.runtime.clients.IClient
-
Returns a set of message types that the client handles.
- getHandler() - Method in class org.corfudb.infrastructure.AbstractServer
-
Get the message handler for this instance.
- getHandler(CorfuMsgType) - Method in class org.corfudb.infrastructure.CorfuMsgHandler
-
Get a handler for a specific message type.
- getHashedConflictSet() - Method in class org.corfudb.runtime.object.transactions.ConflictSetInfo
-
Get the hashed conflict set.
- getHasNext(T) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Return whether calling getNextEntry() may return more
entries, given the context.
- getHasNext(AbstractQueuedStreamView.QueuedStreamContext) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Return whether calling getNextEntry() may return more
entries, given the context.
- getHole(long) - Static method in class org.corfudb.protocols.wireprotocol.LogData
-
- getHost() - Method in interface org.corfudb.runtime.clients.IClientRouter
-
The host that this router is routing requests for.
- getHost() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
- getHost() - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Deprecated.
- getId() - Method in interface org.corfudb.infrastructure.orchestrator.IWorkflow
-
Gets the unique identifier of this workflow instance
- getID() - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- getID() - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
Get the UUID for this stream (optional operation).
- getID() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- getID() - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Deprecated.
- getId() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Return the ID of the stream this view is for.
- getId() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- getID() - Method in class org.corfudb.samples.CorfuCompoundObject
-
- getIfPresent(SequencerServerCache.ConflictTxStream) - Method in class org.corfudb.infrastructure.SequencerServerCache
-
Returns the value associated with the key
in this cache,
or null
if there is no cached value for the key
.
- getIndexFunction() - Method in class org.corfudb.runtime.collections.CorfuTable.Index
-
- getIndexFunction() - Method in interface org.corfudb.runtime.collections.CorfuTable.IndexSpecification
-
- getInstance() - Static method in class org.corfudb.universe.group.cluster.vm.RemoteOperationHelper
-
- getInstance() - Static method in class org.corfudb.universe.universe.docker.FakeDns
-
- getInstance() - Static method in class org.corfudb.universe.UniverseFactory
-
- getIpAddress() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- getIpAddress() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
- getIpAddress() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- getKeyStorePassword(String) - Static method in class org.corfudb.security.tls.TlsUtils
-
Get the password from file.
- getLastAddedNodeInLastSegment() - Method in class org.corfudb.runtime.view.Layout
-
Get the last node in the last segment.
- getLatestSegment() - Method in class org.corfudb.runtime.view.Layout
-
Return latest segment.
- getLayout() - Method in class org.corfudb.runtime.clients.LayoutClient
-
Retrieves the layout from the endpoint, asynchronously.
- getLayout() - Method in class org.corfudb.runtime.clients.ManagementClient
-
Requests for the layout persisted by the management server.
- getLayout() - Method in class org.corfudb.runtime.view.LayoutView
-
Retrieves current layout.
- getLayout() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
- getLayout() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- getLayoutClient(String) - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getLegacyEndpoint(NodeLocator) - Static method in class org.corfudb.util.NodeLocator
-
Creates and returns the endpoint address in the legacy format host:port.
- getLocalAddress(long) - Method in class org.corfudb.runtime.view.Layout
-
Given the log's global address, return equivalent local address for a striped log segment.
- getLocalCorfuClient() - Method in class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
- getLocalCorfuClient() - Method in interface org.corfudb.universe.group.cluster.CorfuCluster
-
Provides a corfu client running on local machine
- getLocalNodeConnectivity() - Method in class org.corfudb.protocols.wireprotocol.ClusterState
-
- getLogAddressSpace() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Get the address space for all streams in the log.
- getLogAddressSpace() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Get log address space, which includes:
1.
- getLogAddressSpace(Layout, CorfuRuntime) - Static method in class org.corfudb.util.Utils
-
Retrieve the space of addresses of the log, i.e., for all streams in the log.
- getLogEntry(CorfuRuntime) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return the payload as a log entry.
- getLogTail() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- getLogTail() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Get the global log tail.
- getLogTail() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- getLogTail() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Get the global tail maximum address the log unit has written.
- getLogTail() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Get the log's tail, i.e., last address in the address space.
- getLogTail(Layout, CorfuRuntime) - Static method in class org.corfudb.util.Utils
-
Get global log tail.
- getLogUnitClient(long, int) - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getLogUnitClient(String) - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getLogUnitEpochWaterMark() - Method in class org.corfudb.infrastructure.ServerContext
-
Fetches the epoch at which the last epochWaterMark operation was received.
- getManagementClient(String) - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getManagementLayout() - Method in class org.corfudb.infrastructure.ServerContext
-
Fetches the management layout from the persistent datastore.
- getManagementView() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
See CorfuRuntime#getManagementView()
- getManagementView() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- getMap(UUID) - Method in class org.corfudb.generator.State
-
- getMaps() - Method in class org.corfudb.generator.State
-
- getMechanismName() - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer
-
- getMechanismNames(Map<String, ?>) - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer.PlainTextSaslServerFactory
-
- getMetadataMap() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getMetadataMap() - Method in class org.corfudb.protocols.wireprotocol.WriteRequest
-
- getMethodFromToString(String) - Static method in class org.corfudb.util.ReflectionUtils
-
Extract method name from to string path.
- getMethodNameOnlyFromString(String) - Static method in class org.corfudb.util.ReflectionUtils
-
- getMinReplicationFactor(Layout, Layout.LayoutStripe) - Method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
Compute the min replication factor for the log unit servers in the replication protocol
for a specific stripe.
- getMsgHandler() - Method in interface org.corfudb.runtime.clients.IClient
-
- getMultiValueIndexFunction() - Method in class org.corfudb.runtime.collections.CorfuTable.Index
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.Action
-
Returns the name of this action.
- getName() - Method in class org.corfudb.infrastructure.orchestrator.actions.RestoreRedundancyMergeSegments
-
- getName() - Method in interface org.corfudb.infrastructure.orchestrator.IWorkflow
-
Return the name of this workflow
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow.BootstrapNode
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow.RestoreRedundancy
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.ForceRemoveWorkflow
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.HealNodeWorkflow
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.RemoveNodeWorkflow
-
- getName() - Method in class org.corfudb.infrastructure.orchestrator.workflows.RestoreRedundancyMergeSegmentsWorkflow
-
- getName() - Method in class org.corfudb.runtime.collections.CorfuTable.Index
-
- getName() - Method in interface org.corfudb.universe.group.Group.GroupParams
-
- getName() - Method in interface org.corfudb.universe.node.Node.NodeParams
-
- getName() - Method in class org.corfudb.universe.node.server.CorfuServerParams
-
- getNegotiatedProperty(String) - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer
-
- getNettyChannelOptions() - Method in class org.corfudb.runtime.CorfuRuntime.CorfuRuntimeParameters
-
Get the netty channel options to be used by the netty client implementation.
- getNetworkInterface() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- getNetworkInterface() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
- getNetworkInterface() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- getNewSingleNodeLayout() - Method in class org.corfudb.infrastructure.ServerContext
-
Get a new single node layout used for self-bootstrapping a server started with
the -s flag.
- getNextEntries(T, long, Function<ILogData, Boolean>) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Retrieve the next entries in the stream, given the context.
- getNextEntries(AbstractQueuedStreamView.QueuedStreamContext, long, Function<ILogData, Boolean>) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Retrieve the next entries in the stream, given the context.
- getNextEntry(T, long) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Retrieve the next entry in the stream, given the context.
- getNextEntry(AbstractQueuedStreamView.QueuedStreamContext, long) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Retrieve the next entry in the stream, given the context.
- getNode(String) - Method in class org.corfudb.protocols.wireprotocol.ClusterState
-
- getNode(String) - Method in class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
- getNode(String) - Method in class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- getNode(String) - Method in interface org.corfudb.universe.group.Group
-
- getNodeConnectivity(String) - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Get node by name
- getNodeId() - Method in class org.corfudb.infrastructure.ServerContext
-
Get the node id as an UUID.
- getNodeIdBase64() - Method in class org.corfudb.infrastructure.ServerContext
-
Get the node id as a base64 string.
- getNodesParams() - Method in class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- getNodesParams() - Method in interface org.corfudb.universe.group.Group.GroupParams
-
- getNodeType() - Method in interface org.corfudb.universe.group.Group.GroupParams
-
- getNodeType() - Method in interface org.corfudb.universe.node.Node.NodeParams
-
- getNotReadyNodeState(String, long, long) - Static method in class org.corfudb.protocols.wireprotocol.NodeState
-
- getNumberOfStripes() - Method in class org.corfudb.runtime.view.Layout.LayoutSegment
-
- getObjectBuilder() - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Get an object builder to build new objects.
- getObjectBuilder() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Get an object builder to build new objects.
- getObjectsView() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
See CorfuRuntime#getObjectsView()
- getObjectsView() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- getObjectType() - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Return the type of the object being replicated.
- getObjectType() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Return the type of the object being replicated.
- getOptimisticStreamUnsafe() - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Get a handle to the optimistic stream.
- getOption(Map<String, Object>, String, Class<T>, T) - Static method in class org.corfudb.util.Utils
-
- getOption(Map<String, Object>, String, Class<T>) - Static method in class org.corfudb.util.Utils
-
- getOrchestrator(Layout) - Method in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
Select an orchestrator and return a client.
- getOrDefault(Object, V) - Method in class org.corfudb.runtime.collections.CorfuTable
- getOrDefault(Object, V) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Returns the value to which the specified key is mapped, or
defaultValue
if this map contains no mapping for the key.
- getOverwriteCauseForAddress(long, LogData) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Get overwrite cause for a given address.
- getParams() - Method in interface org.corfudb.universe.group.Group
-
- getParams() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
- getParams() - Method in interface org.corfudb.universe.node.Node
-
- getParams() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- getPayload(CorfuRuntime) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- getPayload() - Method in class org.corfudb.protocols.wireprotocol.JSONPayloadMsg
-
Get the payload.
- getPayload(CorfuRuntime) - Method in class org.corfudb.protocols.wireprotocol.LogData
-
Return the payload.
- getPhase1Rank() - Method in class org.corfudb.infrastructure.LayoutServer
-
- getPhase1Rank() - Method in class org.corfudb.infrastructure.ServerContext
-
- getPhase2Data() - Method in class org.corfudb.infrastructure.LayoutServer
-
- getPhase2Data() - Method in class org.corfudb.infrastructure.ServerContext
-
- getPhase2Rank() - Method in class org.corfudb.infrastructure.LayoutServer
-
Returns the phase 2 rank.
- getPort() - Method in interface org.corfudb.runtime.clients.IClientRouter
-
The port that this router is routing requests for.
- getPort() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
- getPort() - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Deprecated.
- getPrefixSegments(long) - Method in class org.corfudb.runtime.view.Layout
-
Return a list of segments which contain global
addresses less than or equal to the given address
(known as the prefix).
- getPrimarySequencer() - Method in class org.corfudb.runtime.view.Layout
-
Returns the primary sequencer.
- getPrimarySequencerClient() - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getPrimitiveType(String) - Static method in class org.corfudb.util.ReflectionUtils
-
- getProjectionFunction() - Method in interface org.corfudb.runtime.collections.CorfuTable.IndexSpecification
-
- getProposedLayout() - Method in class org.corfudb.infrastructure.LayoutServer
-
Returns the proposed layout received in phase 2 data.
- getQuorumFuture(Comparator<R>, CompletableFuture<R>[], Class...) - Static method in class org.corfudb.runtime.view.QuorumFuturesFactory
-
Get a thread safe future that will complete only when n/2+1 futures complete or if there
is no hope (if n/2+1 futures are canceled or have conflicting value).
- getQuorumNumber() - Method in class org.corfudb.runtime.view.LayoutView
-
Retrieves the number of nodes needed to obtain a quorum.
- getRandomOpenPort() - Static method in class org.corfudb.universe.node.server.ServerUtil
-
- getRandomOperation() - Method in class org.corfudb.generator.distributions.Operations
-
- getRank() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Get the rank of this append.
- getReachableNodes() - Method in class org.corfudb.infrastructure.management.PollReport
-
Contains list of servers successfully connected with current node.
- getReplicationMode(long) - Method in class org.corfudb.runtime.view.Layout
-
Get the replication mode of a segment at a particular address.
- getReplicationProtocol(CorfuRuntime) - Method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
- getRepositoryState() - Static method in class org.corfudb.util.GitRepositoryState
-
Return git repo state.
- getRootContext() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Returns the last transactional context (parent/root) for the calling thread.
- getRouter() - Method in interface org.corfudb.runtime.clients.IClient
-
Get the router used by the Netty client.
- getRouter(String) - Method in class org.corfudb.runtime.CorfuRuntime
-
Get a router, given the address.
- getRouter(NodeLocator) - Method in class org.corfudb.runtime.NodeRouterPool
-
Fetches a router from the pool if already present.
- getRunFunction() - Method in interface org.corfudb.util.retry.IRetry
-
Get the function that needs to be retried.
- getRuntime() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
See CorfuRuntime()
- getRuntime() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- getRuntimeLayout() - Method in class org.corfudb.runtime.view.LayoutView
-
- getRuntimeLayout(Layout) - Method in class org.corfudb.runtime.view.LayoutView
-
- getSegment(long) - Method in class org.corfudb.runtime.view.Layout
-
Return layout segment.
- getSegmentLength(long) - Method in class org.corfudb.runtime.view.Layout
-
Get the length of a segment at a particular address.
- getSegmentsForEndpoint(String) - Method in class org.corfudb.runtime.view.Layout
-
Return all the segments that an endpoint participates in.
- getSequence() - Method in interface org.corfudb.protocols.wireprotocol.IToken
-
The value of the token, which represents the global address
on the log the token is for.
- getSequence() - Method in class org.corfudb.protocols.wireprotocol.TokenResponse
-
- getSequencerClient(String) - Method in class org.corfudb.runtime.view.RuntimeLayout
-
- getSequencerEpoch() - Method in class org.corfudb.infrastructure.ServerContext
-
Fetch the persisted sequencer epoch.
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.ILogData.SerializationHandle
-
Explicitly request the serialized form of this log data
which only exists for the lifetime of this handle.
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.AddNodeRequest
-
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.CreateWorkflowResponse
-
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.HealNodeRequest
-
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.QueryRequest
-
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.QueryResponse
-
- getSerialized() - Method in interface org.corfudb.protocols.wireprotocol.orchestrator.Request
-
Serialize this request into a byte array
- getSerialized() - Method in interface org.corfudb.protocols.wireprotocol.orchestrator.Response
-
Serialize this response into a byte array
- getSerialized() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.RestoreRedundancyMergeSegmentsRequest
-
- getSerializedForm() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- getSerializedSize(Object) - Static method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return the serialized size of an object
- getSerializer() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxyInternal
-
Deprecated.
Get the serializer used for serializing arguments in the
proxy.
- getSerializer(Byte) - Static method in class org.corfudb.util.serializer.Serializers
-
Return the serializer byte.
- getServerByIndex(int) - Method in interface org.corfudb.universe.group.cluster.CorfuCluster
-
Find a corfu server by index in the cluster:
- get all corfu servers in the cluster
- skip particular number of servers in the cluster according to index offset
- extract first server from the list
- getServerConfig(Class<T>, String) - Method in class org.corfudb.infrastructure.ServerContext
-
Get a field from the server configuration map.
- getServerEpoch() - Method in interface org.corfudb.infrastructure.IServerRouter
-
Get the current epoch.
- getServerEpoch() - Method in class org.corfudb.infrastructure.ServerContext
-
The epoch of this router.
- getServerLogDir() - Method in class org.corfudb.universe.logging.LoggingParams
-
- getServers() - Method in interface org.corfudb.infrastructure.IServerRouter
-
Get a list of registered servers.
- getServers() - Method in class org.corfudb.infrastructure.NettyServerRouter
-
Get a list of registered servers.
- getServers() - Method in class org.corfudb.infrastructure.ServerContext
-
Get the list of servers registered in serverRouter
- getShortMethodName(String) - Static method in class org.corfudb.util.ReflectionUtils
-
- getSizeEstimate() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Get an estimate of how large this entry is in memory.
- getSizeEstimate() - Method in class org.corfudb.protocols.wireprotocol.LogData
-
- getSmrFunctionName(ExecutableElement) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
-
Return a SMR function name, extracting it from the annotations if available.
- getSMRUpdates(UUID) - Method in interface org.corfudb.protocols.logprotocol.ISMRConsumable
-
Deprecated.
- getSMRUpdates(UUID) - Method in class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
Get the list of SMR updates for a particular object.
- getSMRUpdates(UUID) - Method in class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- getSMRUpdates(UUID) - Method in class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
- getStartingAddress() - Method in class org.corfudb.infrastructure.log.StreamLogDataStore
-
Returns the dataStore starting address.
- getState() - Method in class org.corfudb.infrastructure.AbstractServer
-
- getStatus() - Method in class org.corfudb.infrastructure.orchestrator.Action
-
Get the status of this action.
- getStreamAddressSpace(StreamAddressRange) - Method in class org.corfudb.runtime.view.SequencerView
-
Retrieve a stream's address space from sequencer server.
- getStreamEntry(UUID) - Method in class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
Extract a particular stream's entry from this object.
- getStreamID(String) - Static method in class org.corfudb.runtime.CorfuRuntime
-
Get a UUID for a named stream.
- getStreamID() - Method in class org.corfudb.runtime.object.AbstractCorfuWrapper
-
Deprecated.
- getStreamID() - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Get the ID of the stream this proxy is subscribed to.
- getStreamID() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Get the ID of the stream this proxy is subscribed to.
- getStreamLogDir() - Method in class org.corfudb.universe.node.server.CorfuServerParams
-
- getStreams() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Get the streams that belong to this append.
- getStreamsAddressSpace() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- getStreamsAddressSpace() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Get the address space for every stream.
- getStreamsAddressSpace() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- getStreamsAddressSpace(List<StreamAddressRange>) - Method in class org.corfudb.runtime.clients.SequencerClient
-
Retrieves from the sequencer the address space for the specified streams in the given ranges.
- getStreamsAddressSpace(List<StreamAddressRange>) - Method in class org.corfudb.runtime.view.SequencerView
-
Retrieve multiple streams address space.
- getStreamView(CorfuRuntime, UUID, StreamOptions) - Method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
- getStress() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- getStress() - Method in interface org.corfudb.universe.node.Node
-
- getStress() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
- getStress() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- getStripe(long) - Method in class org.corfudb.runtime.view.Layout
-
Return layout segment stripe.
- getSupportedSourceVersion() - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
-
Always support the latest source version.
- getTail() - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Get tail for this stream.
- getTails(List<UUID>) - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- getTails(List<UUID>) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Get the global tail and stream tails.
- getTails(List<UUID>) - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- getTailSegment() - Method in class org.corfudb.infrastructure.log.StreamLogDataStore
-
Return current cached tail segment or get the segment from the data store if not initialized
- getThreadId() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getThreadPrefix() - Method in class org.corfudb.infrastructure.ServerContext
-
Get the prefix for threads this server creates.
- getThrowables() - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
Returns a set of Throwable classes from all futures that completed in any exceptional
fashion.
- getToken() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- getTotalUpdates() - Method in class org.corfudb.runtime.view.stream.AddressMapStreamView
-
- getTotalUpdates() - Method in class org.corfudb.runtime.view.stream.BackpointerStreamView
-
- getTotalUpdates() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Get total number of updates registered to this stream.
- getTotalUpdates() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- getTransactionStack() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Returns the transaction stack for the calling thread.
- getTransactionStackAsList() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Get the transaction stack as a list.
- getTrimMark() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- getTrimMark() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Get the first untrimmed address in the address space.
- getTrimMark() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- getTrimMark() - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Get the starting address of a log unit.
- getTrimMark() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Get the first address in the address space.
- getTrimMark() - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
- getTrimmed(long) - Static method in class org.corfudb.protocols.wireprotocol.LogData
-
- getType() - Method in interface org.corfudb.infrastructure.management.ClusterAdvisor
-
- getType() - Method in class org.corfudb.infrastructure.management.CompleteGraphAdvisor
-
- getType() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.AddNodeRequest
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.CreateWorkflowResponse
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.ForceRemoveNodeRequest
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.HealNodeRequest
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.QueryRequest
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.QueryResponse
-
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.RemoveNodeRequest
-
- getType() - Method in interface org.corfudb.protocols.wireprotocol.orchestrator.Request
-
Returns the type of the request.
- getType() - Method in interface org.corfudb.protocols.wireprotocol.orchestrator.Response
-
Returns the type of the response.
- getType() - Method in class org.corfudb.protocols.wireprotocol.orchestrator.RestoreRedundancyMergeSegmentsRequest
-
- getType() - Method in class org.corfudb.util.serializer.CorfuSerializer
-
- getType() - Method in interface org.corfudb.util.serializer.ISerializer
-
- getType() - Method in class org.corfudb.util.serializer.JavaSerializer
-
- getType() - Method in class org.corfudb.util.serializer.JsonSerializer
-
- getType() - Method in class org.corfudb.util.serializer.PrimitiveSerializer
-
- getUnavailableNodeState(String) - Static method in class org.corfudb.protocols.wireprotocol.NodeState
-
- getUnderlyingObject() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxyInternal
-
Deprecated.
Directly get the state of the object the proxy is managing,
without causing a sync.
- getUndoRecord(R, Object[]) - Method in interface org.corfudb.runtime.object.IUndoRecordFunction
-
Generate an undo record.
- getUninterruptibly(Future<T>, Class<A>, Class<B>, Class<C>, Class<D>) - Static method in class org.corfudb.util.CFUtils
-
- getUninterruptibly(Future<T>, Class<A>, Class<B>, Class<C>) - Static method in class org.corfudb.util.CFUtils
-
- getUninterruptibly(Future<T>, Class<A>, Class<B>) - Static method in class org.corfudb.util.CFUtils
-
- getUninterruptibly(Future<T>, Class<A>) - Static method in class org.corfudb.util.CFUtils
-
- getUninterruptibly(Future<T>) - Static method in class org.corfudb.util.CFUtils
-
- getUniverseParams() - Method in class org.corfudb.universe.universe.process.ProcessUniverse
-
- getUniverseParams() - Method in interface org.corfudb.universe.universe.Universe
-
- getUnsafe(UUID) - Method in class org.corfudb.runtime.view.StreamsView
-
Since streams can also be used by higher level abstractions, some consumers implement
synchronization at a higher level, so the stream implementation doesn't have to
be thread-safe.
- getUnsafe(UUID, StreamOptions) - Method in class org.corfudb.runtime.view.StreamsView
-
- getUnsafeStreamView(CorfuRuntime, UUID, StreamOptions) - Method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
- getUpcallResult(long, Object[]) - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Return the result of an upcall at the given timestamp.
- getUpcallResult(long, Object[]) - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Return the result of an upcall at the given timestamp.
- getUpcallResult(ICorfuSMRProxyInternal<T>, long, Object[]) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
Get the result of an upcall.
- getUpcallResult(ICorfuSMRProxyInternal<T>, long, Object[]) - Method in class org.corfudb.runtime.object.transactions.OptimisticTransactionalContext
-
if a Corfu object's method is an Accessor-Mutator, then although the mutation is delayed,
it needs to obtain the result by invoking getUpcallResult() on the optimistic stream.
- getUpcallResult(ICorfuSMRProxyInternal<T>, long, Object[]) - Method in class org.corfudb.runtime.object.transactions.SnapshotTransactionalContext
-
Get the result of an upcall.
- getUser() - Method in class org.corfudb.samples.CorfuCompoundObject
-
- getVersion() - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Get the latest version read by the proxy.
- getVersion() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Get the latest version read by the proxy.
- getVersionInfo() - Method in class org.corfudb.runtime.clients.BaseClient
-
- getVersionString() - Static method in class org.corfudb.runtime.CorfuRuntime
-
Get corfu runtime version.
- getVersionUnsafe() - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Get the version of this object.
- getVms() - Method in class org.corfudb.universe.universe.vm.ApplianceManager
-
- getWrapper(Class<T>, CorfuRuntime, UUID, Object[], ISerializer) - Static method in class org.corfudb.runtime.object.CorfuCompileWrapperBuilder
-
Deprecated.
- GitRepositoryState - Class in org.corfudb.util
-
Created by mwei on 8/12/15.
- globalPointer - Variable in class org.corfudb.runtime.view.stream.AbstractStreamContext
-
A pointer to the current global address, which is the
global address of the most recently added entry.
- Group - Interface in org.corfudb.universe.group
-
This provides an abstraction for a group of
Node
s that come together to provide a logical service.
- Group.GroupParams - Interface in org.corfudb.universe.group
-
- groups - Variable in class org.corfudb.universe.universe.AbstractUniverse
-
- groups() - Method in class org.corfudb.universe.universe.AbstractUniverse
-
- groups() - Method in class org.corfudb.universe.universe.process.ProcessUniverse
-
- groups() - Method in interface org.corfudb.universe.universe.Universe
-
- handle(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.CorfuMsgHandler
-
Handle an incoming CorfuMsg.
- handle(CorfuPayloadMsg<OrchestratorMsg>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.orchestrator.Orchestrator
-
- handle(CorfuMsg, ChannelHandlerContext) - Method in class org.corfudb.runtime.clients.ClientMsgHandler
-
Handle an incoming CorfuMsg.
- handle(T, ChannelHandlerContext, IClientRouter) - Method in interface org.corfudb.runtime.clients.ClientMsgHandler.Handler
-
- handle(Callback[]) - Method in class org.corfudb.security.sasl.plaintext.PlainTextCallbackHandler
-
Call functions for username & password for SASL callbacks.
- handleFailure(IReconfigurationHandlerPolicy, Layout, CorfuRuntime, Set<String>) - Static method in class org.corfudb.infrastructure.management.ReconfigurationEventHandler
-
Takes in the existing layout and a set of failed nodes.
- handleFailure(long, Set<String>) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Sends the failure detected to the relevant management server.
- handleFailure(IReconfigurationHandlerPolicy, Layout, Set<String>) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Takes in the existing layout and a set of failed nodes.
- handleFailureDetectedMsg(CorfuPayloadMsg<DetectorMsg>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
Triggers the failure handler.
- handleFailureDetectorMetricsRequest(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
- handleHealing(CorfuRuntime, Set<String>, Duration) - Static method in class org.corfudb.infrastructure.management.ReconfigurationEventHandler
-
Takes in the existing layout and a set of healed nodes.
- handleHealing(long, Set<String>) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Sends the healed nodes detected to the relevant management server.
- handleHealingDetectedMsg(CorfuPayloadMsg<DetectorMsg>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
Triggers the healing handler.
- handleLayoutRequest(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
Handles the Management layout request.
- handleLogAddressSpaceRequest(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LogUnitServer
-
Service an incoming request for log address space, i.e., the map of addresses for every stream in the log.
- handleManagementBootstrap(CorfuPayloadMsg<Layout>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
Bootstraps the management server.
- handleMergeSegments(CorfuRuntime, Layout, Duration) - Static method in class org.corfudb.infrastructure.management.ReconfigurationEventHandler
-
Launches a workflow to restore redundancy and merge all segments.
- handleMessage(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.AbstractServer
-
Handle a incoming Netty message.
- handleMessage(CorfuMsg, ChannelHandlerContext) - Method in interface org.corfudb.runtime.clients.IClient
-
Handle a incoming message on the channel.
- handleMessageLayoutBootstrap(CorfuPayloadMsg<LayoutBootstrapRequest>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LayoutServer
-
Sets the new layout if the server has not been bootstrapped with one already.
- handleMessageLayoutCommit(CorfuPayloadMsg<LayoutCommittedRequest>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LayoutServer
-
Accepts any committed layouts for the current epoch or newer epochs.
- handleMessageLayoutPrepare(CorfuPayloadMsg<LayoutPrepareRequest>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LayoutServer
-
Accepts a prepare message if the rank is higher than any accepted so far.
- handleMessageLayoutPropose(CorfuPayloadMsg<LayoutProposeRequest>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LayoutServer
-
Accepts a proposal for which it had accepted in the prepare phase.
- handleMessageLayoutRequest(CorfuPayloadMsg<Long>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LayoutServer
-
Handle a layout request message.
- handleMessageSetEpoch(CorfuPayloadMsg<Long>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.BaseServer
-
Respond to a epoch change message.
- handleMetricsRequest(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.SequencerServer
-
Service an incoming metrics request with the metrics response.
- handleNodeStateRequest(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
Returns current
NodeState
provided by failure detector.
- handleOrchestratorMsg(CorfuPayloadMsg<OrchestratorMsg>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.ManagementServer
-
Forward an orchestrator request to the orchestrator service.
- handlerMap - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
The handlers registered to this router.
- handleTailRequest(CorfuPayloadMsg<TailsRequest>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LogUnitServer
-
Service an incoming request for maximum global address the log unit server has written.
- handleTrimMarkRequest(CorfuMsg, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LogUnitServer
-
Service an incoming request to retrieve the starting address of this logging unit.
- HandshakeMsg - Class in org.corfudb.protocols.wireprotocol
-
Message sent to initiate handshake between client and server.
- HandshakeMsg(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.HandshakeMsg
-
Constructor to generate an initiating Handshake Message Payload.
- HandshakeResponse - Class in org.corfudb.protocols.wireprotocol
-
Response sent by server in the handshake stage.
- HandshakeResponse(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.HandshakeResponse
-
- HandshakeState - Class in org.corfudb.protocols.wireprotocol
-
Created by amartinezman on 12/20/17.
- HandshakeState() - Constructor for class org.corfudb.protocols.wireprotocol.HandshakeState
-
Keeps state of the handshake, initiated between client and server.
- hasBackpointer(UUID) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return if there is backpointer for a particular stream.
- hasCheckpointMetadata() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- hash(Object) - Method in interface org.corfudb.util.serializer.ISerializer
-
Given an object, generate a hash for it.
- hashCode() - Method in class org.corfudb.runtime.collections.CorfuTable.Index
-
- hashCode() - Method in interface org.corfudb.runtime.collections.ISMRObject
-
Deprecated.
- hashConversionMap - Static variable in interface org.corfudb.util.serializer.ISerializer
-
This map provides some methods for performing hashing on
known types.
- hasNext() - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Returns whether or not there are potentially more entries in this
stream - this function may return true even if there are no entries
remaining, as addresses may have been acquired by other clients
but not written yet, or the addresses were hole-filled, or just failed.
- hasNext() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Returns whether or not there are potentially more entries in this
stream - this function may return true even if there are no entries
remaining, as addresses may have been acquired by other clients
but not written yet, or the addresses were hole-filled, or just failed.
- hasNext() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- hasSecondaryIndices() - Method in class org.corfudb.runtime.collections.CorfuTable
-
Return whether this table has secondary indexes or not.
- haveUpcallResult - Variable in class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
If there is an upcall result for this modification.
- healedServer(ClusterState, List<String>) - Method in interface org.corfudb.infrastructure.management.ClusterAdvisor
-
Provide a server in the Corfu cluster which according to the underlying algorithm
for
ClusterType
have healed.
- healedServer(ClusterState, List<String>) - Method in class org.corfudb.infrastructure.management.CompleteGraphAdvisor
-
Provide a server considered to have healed in the Corfu cluster according to
the COMPLETE_GRAPH implementation of algorithm for
ClusterType
.
- healNode(Layout, String) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Heals an existing node in the layout.
- healNode(String, int, Duration, Duration) - Method in class org.corfudb.runtime.view.ManagementView
-
Heal an unresponsive node.
- HealNode - Class in org.corfudb.runtime.view.workflows
-
- HealNode(String, CorfuRuntime, int, Duration, Duration) - Constructor for class org.corfudb.runtime.view.workflows.HealNode
-
- HealNodeRequest - Class in org.corfudb.protocols.wireprotocol.orchestrator
-
An orchestrator request to heal an existing node to the cluster.
- HealNodeRequest(String, boolean, boolean, boolean, int) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.HealNodeRequest
-
- HealNodeRequest(byte[]) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.HealNodeRequest
-
- healNodeRequest(String, boolean, boolean, boolean, int) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Creates a workflow request to heal a node.
- HealNodeWorkflow - Class in org.corfudb.infrastructure.orchestrator.workflows
-
A definition of a workflow that heals an existing unresponsive node back to the cluster.
- HealNodeWorkflow(HealNodeRequest) - Constructor for class org.corfudb.infrastructure.orchestrator.workflows.HealNodeWorkflow
-
- HeartbeatCounter() - Constructor for class org.corfudb.infrastructure.management.ClusterStateContext.HeartbeatCounter
-
- HeartbeatTimestamp(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.NodeState.HeartbeatTimestamp
-
- HelloCorfu - Class in org.corfudb.samples
-
This tutorial demonstrates a simple Corfu application.
- HelloCorfu() - Constructor for class org.corfudb.samples.HelloCorfu
-
- hexdump(ByteBuf) - Static method in class org.corfudb.util.Utils
-
Hex dump readable contents of ByteBuf to stdout.
- hexdump(byte[]) - Static method in class org.corfudb.util.Utils
-
Hex dump contents of byte[] to stdout.
- Holder<T> - Class in org.corfudb.util
-
Holds a reference to a given object
- Holder() - Constructor for class org.corfudb.util.Holder
-
- holeFill(RuntimeLayout, long) - Method in class org.corfudb.runtime.view.replication.AbstractReplicationProtocol
-
Write a special hole filling entry using the
given address.
- holeFill(RuntimeLayout, long) - Method in class org.corfudb.runtime.view.replication.ChainReplicationProtocol
-
Write a special hole filling entry using the
given address.
- holeFill(RuntimeLayout, long) - Method in class org.corfudb.runtime.view.replication.QuorumReplicationProtocol
-
Write a special hole filling entry using the
given address.
- holeFillPolicy - Variable in class org.corfudb.runtime.view.replication.AbstractReplicationProtocol
-
The hole fill policy to apply.
- HoleFillRequiredException - Exception in org.corfudb.runtime.exceptions
-
This exception is thrown whenever a hole fill is required
by policy.
- HoleFillRequiredException(String) - Constructor for exception org.corfudb.runtime.exceptions.HoleFillRequiredException
-
- IClient - Interface in org.corfudb.runtime.clients
-
This is an interface which all clients to a ClientRouter must implement.
- IClientRouter - Interface in org.corfudb.runtime.clients
-
This is an interface in which all client routers must implement.
- IConflictFunction - Interface in org.corfudb.runtime.object
-
A function which is used to getConflictSet the fine-grained conflict set.
- ICorfuHashable - Interface in org.corfudb.util.serializer
-
Represents an object which the serializer may hash.
- ICorfuMap<K,V> - Interface in org.corfudb.runtime.collections
-
- ICorfuPayload<T> - Interface in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/1/16.
- ICorfuPayload.PayloadConstructor<T> - Interface in org.corfudb.protocols.wireprotocol
-
- ICorfuSerializable - Interface in org.corfudb.util.serializer
-
Created by mwei on 9/29/15.
- ICorfuSMR<T> - Interface in org.corfudb.runtime.object
-
The interface for an object interfaced with SMR.
- ICorfuSMRAccess<R,T> - Interface in org.corfudb.runtime.object
-
A functional interface for accessing the state
of an SMR object.
- ICorfuSMRProxy<T> - Interface in org.corfudb.runtime.object
-
An interface for accessing a proxy, which
manages an SMR object.
- ICorfuSMRProxyInternal<T> - Interface in org.corfudb.runtime.object
-
Deprecated.
- ICorfuSMRProxyWrapper<T> - Interface in org.corfudb.runtime.object
-
The interface to a Corfu wrapper.
- ICorfuSMRUpcallTarget<R> - Interface in org.corfudb.runtime.object
-
An interface for SMR object upcalls, which
are recorded on the log.
- id - Variable in class org.corfudb.protocols.wireprotocol.orchestrator.QueryRequest
-
- IDataStore - Interface in org.corfudb.infrastructure
-
Key Value data store abstraction that provides persistence for variables that need
retain values across node restarts or need to be accessed by multiple modules/threads.
- IDataStore.KvRecord<T> - Class in org.corfudb.infrastructure
-
Key-value meta information class, provides all the information for saving and getting data from a data store
- IDetector - Interface in org.corfudb.infrastructure.management
-
Detection Executors.
- IFailureHandlerPolicy - Interface in org.corfudb.runtime.view
-
Failure Handler Policy modifies the current layout based on the
set of failures passed.
- ignoreEpoch - Variable in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
- ignoreTrimmed - Variable in class org.corfudb.runtime.view.StreamOptions
-
- ignoreTrimmed(boolean) - Method in class org.corfudb.runtime.view.StreamOptions.StreamOptionsBuilder
-
- IHandler<C extends org.corfudb.runtime.clients.AbstractClient> - Interface in org.corfudb.runtime.clients
-
Handler Clients to handle the responses form the server.
- IHoleFillPolicy - Interface in org.corfudb.runtime.view.replication
-
Created by mwei on 4/6/17.
- ILogData - Interface in org.corfudb.protocols.wireprotocol
-
An interface to log data entries.
- ILogData.SerializationHandle - Class in org.corfudb.protocols.wireprotocol
-
This class provides a serialization handle, which
manages the lifetime of the serialized copy of this
entry.
- IMetadata - Interface in org.corfudb.protocols.wireprotocol
-
Created by mwei on 9/18/15.
- IMetadata.DataRank - Class in org.corfudb.protocols.wireprotocol
-
- IMetadata.LogUnitMetadataType - Enum in org.corfudb.protocols.wireprotocol
-
- ImmuableListSetWrapper<E> - Class in org.corfudb.util
-
An immutable set implementation that is backed by a list.
- ImmuableListSetWrapper(List<E>) - Constructor for class org.corfudb.util.ImmuableListSetWrapper
-
- impl(CorfuRuntime) - Method in class org.corfudb.infrastructure.orchestrator.Action
-
The implementation of the action
- impl(CorfuRuntime) - Method in class org.corfudb.infrastructure.orchestrator.actions.RestoreRedundancyMergeSegments
-
- impl(CorfuRuntime) - Method in class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow.BootstrapNode
-
Completes if bootstrap was successful.
- impl(CorfuRuntime) - Method in class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow.RestoreRedundancy
-
- InboundMsgFilterHandler - Class in org.corfudb.protocols.wireprotocol
-
Represent a Netty handler in charge of applying filters on the inbound
Corfu messages in order to transform them.
- InboundMsgFilterHandler(List<MsgHandlingFilter>) - Constructor for class org.corfudb.protocols.wireprotocol.InboundMsgFilterHandler
-
- incConditionalCounter(boolean, Counter, long) - Static method in class org.corfudb.util.MetricsUtils
-
- Increment() - Method in class org.corfudb.samples.CorfuSharedCounter
-
Increment() method is annotated as a MutatorAccessor Method.
- incrementHeartbeat() - Method in class org.corfudb.infrastructure.management.ClusterStateContext.HeartbeatCounter
-
Increment local heartbeat counter.
- Index(CorfuTable.IndexName, CorfuTable.IndexFunction<K, V, I>) - Constructor for class org.corfudb.runtime.collections.CorfuTable.Index
-
- Index(CorfuTable.IndexName, CorfuTable.MultiValueIndexFunction<K, V, I>) - Constructor for class org.corfudb.runtime.collections.CorfuTable.Index
-
- init(ProcessingEnvironment) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.corfudb.security.sasl.plaintext.PlainTextLoginModule
-
- initialize() - Static method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServerProvider
-
- InMemoryStreamLog - Class in org.corfudb.infrastructure.log
-
This class implements the StreamLog interface using a Java hash map.
- InMemoryStreamLog() - Constructor for class org.corfudb.infrastructure.log.InMemoryStreamLog
-
Returns an object that stores a stream log in memory.
- Inner(String, String) - Constructor for class org.corfudb.samples.CorfuCompoundObject.Inner
-
- insert(K, V) - Method in class org.corfudb.runtime.collections.CorfuTable
-
Insert a key-value pair into a map, overwriting any previous mapping.
- insert(K, V) - Method in interface org.corfudb.runtime.collections.ICorfuMap
-
Insert a key-value pair into a map, overwriting any previous mapping.
- insnToString(AbstractInsnNode) - Static method in class org.corfudb.util.Utils
-
- install() - Method in class org.corfudb.universe.universe.docker.FakeDns
-
Install the fake DNS resolver into the Java runtime.
- installSingleNodeLayoutIfAbsent() - Method in class org.corfudb.infrastructure.ServerContext
-
Install a single node layout if and only if no layout is currently installed.
- instantiateCorfuObject(Class<T>, String) - Method in class org.corfudb.samples.BaseCorfuAppUtils
-
Utility method to instantiate a Corfu object
A Corfu Stream is a log dedicated specifically to the history of updates of one object.
- instantiateCorfuObject(TypeToken<T>, String) - Method in class org.corfudb.samples.BaseCorfuAppUtils
-
Utility method to instantiate a Corfu object
A Corfu Stream is a log dedicated specifically to the history of updates of one object.
- Instrumented - Annotation Type in org.corfudb.annotations
-
Marks that a method has been instrumented by the runtime.
- InstrumentedCorfuObject - Annotation Type in org.corfudb.annotations
-
Marks that the object has been instrumented by the runtime.
- InterfaceOverride - Annotation Type in org.corfudb.annotations
-
Marks that a interface method (marked default) should
be used instead of any implementation from a derived class.
- IntervalRetry<E extends Exception,F extends Exception,G extends Exception,H extends Exception,O> - Class in org.corfudb.util.retry
-
This class implements a basic interval-based retry.
- IntervalRetry(IRetryable<E, F, G, H, O>) - Constructor for class org.corfudb.util.retry.IntervalRetry
-
- intToBigEndianByteArray(int) - Static method in class org.corfudb.util.Utils
-
- INVALID_EPOCH - Static variable in class org.corfudb.runtime.view.Layout
-
Invalid epoch value.
- INVALID_HEARTBEAT_COUNTER - Static variable in class org.corfudb.protocols.wireprotocol.NodeState
-
- invalidateAll() - Method in class org.corfudb.infrastructure.SequencerServerCache
-
Discard all entries in the cache
- invalidateClientCache() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Force the client cache to be invalidated.
- invalidateLayout() - Method in class org.corfudb.runtime.CorfuRuntime
-
Invalidate the current layout.
- invalidateLayout() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
- invalidateLayout() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- invalidateServerCaches() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Force all server caches to be invalidated.
- invalidateUpTo(long) - Method in class org.corfudb.infrastructure.SequencerServerCache
-
Invalidate all records up to a trim mark.
- invoke() - Method in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
Starts executing the workflow request.
- IObjectBuilder<T> - Interface in org.corfudb.runtime.object
-
The interface to the builder for an object.
- IpTablesUtil - Class in org.corfudb.universe.util
-
Iptables wrapper/utility class
- IReconfigurationHandlerPolicy - Interface in org.corfudb.runtime.view
-
Failure Handler Policy modifies the current layout based on the
set of failures passed.
- IReplicationProtocol - Interface in org.corfudb.runtime.view.replication
-
The public interface to a replication protocol.
- IRetry<E extends Exception,F extends Exception,G extends Exception,H extends Exception,O,A extends IRetry> - Interface in org.corfudb.util.retry
-
The IRetry interface is used to support retry loops by using different strategies
for the pause between the retries.
- IRetryable<E extends Exception,F extends Exception,G extends Exception,H extends Exception,T> - Interface in org.corfudb.util.retry
-
Created by mwei on 9/1/15.
- is(String) - Method in class org.corfudb.protocols.wireprotocol.failuredetector.NodeRank
-
- isAddress(long) - Static method in class org.corfudb.runtime.view.Address
-
Returns whether a given address is a valid address or not.
- isCancelled() - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
- isComplete() - Method in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer
-
- isConflict() - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
Returns true if there were two successful results with different values, otherwise false.
- isConnected() - Method in class org.corfudb.protocols.wireprotocol.NodeState
-
- isCurrentLayoutSlotUnFilled() - Method in class org.corfudb.infrastructure.management.PollReport
-
All active Layout servers have been sealed but there is no client to take this forward and
fill the slot by proposing a new layout.
- isDone() - Method in class org.corfudb.runtime.view.QuorumFuturesFactory.CompositeFuture
-
- isEmpty() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return whether the entry represents an empty entry or not.
- isEmpty() - Method in class org.corfudb.runtime.collections.CorfuTable
- isEmpty() - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- isEmpty() - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Checks if this stream has addresses or not.
- isEmpty() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- ISerializer - Interface in org.corfudb.util.serializer
-
This class represents a serializer, which takes an object and reads/writes it to a bytebuf.
- IServerRouter - Interface in org.corfudb.infrastructure
-
Created by mwei on 12/13/15.
- isFirstEntry(UUID) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return if this is the first entry in a particular stream.
- isHole() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return whether the entry represents a hole or not.
- isInNestedTransaction() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Whether or not the current thread is in a nested transaction.
- isInTransaction() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Returns whether or not the calling thread is in a transaction.
- isLogEntry(CorfuRuntime) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return whether or not this entry is a log entry.
- isLoggingEnabled() - Method in class org.corfudb.runtime.object.transactions.Transaction
-
- isMetricsReportingSetUp(MetricRegistry) - Static method in class org.corfudb.util.MetricsUtils
-
Check whether the metrics reporting has been already set up using metricsReportingSetup.
- isMinAddress(long) - Static method in class org.corfudb.runtime.view.Address
-
- ISMRConsumable - Interface in org.corfudb.protocols.logprotocol
-
Deprecated.
- ISMRMap<K,V> - Interface in org.corfudb.runtime.collections
-
Deprecated.
- ISMRMap.UndoNullable - Enum in org.corfudb.runtime.collections
-
Deprecated.
- ISMRObject - Interface in org.corfudb.runtime.collections
-
Deprecated.
- ISMRStream - Interface in org.corfudb.runtime.object
-
Deprecated.
- isMutation(UUID) - Method in class org.corfudb.protocols.logprotocol.LogEntry
-
Returns whether the entry changes the contents of the stream.
- isOptimisticallyModifiedUnsafe() - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Check whether this object is currently under optimistic modifications.
- isReady() - Method in class org.corfudb.protocols.wireprotocol.ClusterState
-
See if cluster is ready.
- isServerReadyToHandleMsg(CorfuMsg) - Method in class org.corfudb.infrastructure.AbstractServer
-
- isServerReadyToHandleMsg(CorfuMsg) - Method in class org.corfudb.infrastructure.BaseServer
-
- isServerReadyToHandleMsg(CorfuMsg) - Method in class org.corfudb.infrastructure.LayoutServer
-
- isServerReadyToHandleMsg(CorfuMsg) - Method in class org.corfudb.infrastructure.LogUnitServer
-
- isServerReadyToHandleMsg(CorfuMsg) - Method in class org.corfudb.infrastructure.ManagementServer
-
- isServerReadyToHandleMsg(CorfuMsg) - Method in class org.corfudb.infrastructure.SequencerServer
-
- isStreamCurrentContextThreadCurrentContext() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
Return whether stream current transaction is the thread current transaction.
- isStreamForThisThread() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
Return whether we are the stream for this current thread
- IStreamView - Interface in org.corfudb.runtime.view.stream
-
This interface represents a view on a stream.
- IStreamView.SearchDirection - Enum in org.corfudb.runtime.view.stream
-
An enum representing search directions.
- isTrimmed() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
Return true if and only if the entry represents a trimmed address.
- it(String, Class<R>, Consumer<Scenario.ScenarioTest<T, R>>) - Method in class org.corfudb.universe.scenario.Scenario.ScenarioTestCase
-
Factory method for creating scenario tests
- it(String, Consumer<T>) - Method in class org.corfudb.universe.scenario.Scenario.ScenarioTestCase
-
- iterator() - Method in class org.corfudb.generator.StringIndexer
-
- iterator() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- IToken - Interface in org.corfudb.protocols.wireprotocol
-
Represents a token, which is a reservation on the log.
- ITypedEnum<T extends Enum<T>> - Interface in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/9/16.
- IUndoFunction<R> - Interface in org.corfudb.runtime.object
-
A functional interface which represents an undo function.
- IUndoRecordFunction<R> - Interface in org.corfudb.runtime.object
-
A functional interface which represents a function which generates an
undo record.
- IWorkflow - Interface in org.corfudb.infrastructure.orchestrator
-
A workflow is an abstract container that specifies a series of ordered steps that achieves a
multi-step operation.
- main(String[]) - Static method in class org.corfudb.generator.Generator
-
- main(String[]) - Static method in class org.corfudb.generator.LongevityRun
-
- main(String[]) - Static method in class org.corfudb.infrastructure.CorfuServer
-
Main program entry point.
- main(String[]) - Static method in class org.corfudb.metrics.MBeanDumperApp
-
- main(String[]) - Static method in class org.corfudb.samples.BatchedWriteTransaction
-
- main(String[]) - Static method in class org.corfudb.samples.HelloCorfu
-
- main(String[]) - Static method in class org.corfudb.samples.SimpleAtomicTransaction
-
- main(String[]) - Static method in class org.corfudb.samples.SimpleUseBaseCorfuCollections
-
- main(String[]) - Static method in class org.corfudb.samples.SimpleUseCustomBaseCorfuObject
-
- main(String[]) - Static method in class org.corfudb.samples.WriteOnlySimpleTransaction
-
- main(String[]) - Static method in class org.corfudb.samples.WriteWriteTXs
-
- main(String[]) - Static method in class org.corfudb.shell.ShellMain
-
- ManagementAgent - Class in org.corfudb.infrastructure
-
Instantiates and performs failure detection and handling asynchronously.
- ManagementClient - Class in org.corfudb.runtime.clients
-
A client to the Management Server.
- ManagementClient(IClientRouter, long) - Constructor for class org.corfudb.runtime.clients.ManagementClient
-
- ManagementHandler - Class in org.corfudb.runtime.clients
-
A client to handle the responses from the Management Server.
- ManagementHandler() - Constructor for class org.corfudb.runtime.clients.ManagementHandler
-
- ManagementServer - Class in org.corfudb.infrastructure
-
Handles reconfiguration and workflow requests to the Management Server.
- ManagementServer(ServerContext) - Constructor for class org.corfudb.infrastructure.ManagementServer
-
Returns new ManagementServer.
- ManagementView - Class in org.corfudb.runtime.view
-
A view of the Management Service to manage reconfigurations of the Corfu Cluster.
- ManagementView(CorfuRuntime) - Constructor for class org.corfudb.runtime.view.ManagementView
-
- mapFromBuffer(ByteBuf, Class<K>, Class<V>) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
A really simple flat map implementation.
- mapSecondaryIndexes(K, V) - Method in class org.corfudb.runtime.collections.CorfuTable
-
Maps the secondary indexes for a given key value pair.
- MAX - Static variable in class org.corfudb.runtime.view.Address
-
The maximum address.
- maxNonAddress() - Static method in class org.corfudb.runtime.view.Address
-
- MBeanDumperApp - Class in org.corfudb.metrics
-
An app to dump the MBean object names and their corresponding attributes into disk.
- MBeanDumperApp() - Constructor for class org.corfudb.metrics.MBeanDumperApp
-
- MECHANISM - Static variable in class org.corfudb.security.sasl.plaintext.PlainTextSaslServer
-
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.CorfuTable
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
If the specified key is not already associated with a value or is
associated with null, associates it with the given non-null value.
- mergeInto(MultiObjectSMREntry) - Method in class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
merge two MultiObjectSMREntry records.
- mergeInto(MultiSMREntry) - Method in class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- mergeInto(ConflictSetInfo) - Method in class org.corfudb.runtime.object.transactions.ConflictSetInfo
-
Merge a conflict set into this conflict set.
- mergeInto(ConflictSetInfo) - Method in class org.corfudb.runtime.object.transactions.WriteSetInfo
-
- mergePreviousSegment(int) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Merges the specified segment and the segment before this.
- mergeSegments(String) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Creates a workflow request to restore all redundancies and merge all segments.
- mergeSegments(Layout) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Attempts to merge the last 2 segments.
- mergeSegments(String, int, Duration, Duration) - Method in class org.corfudb.runtime.view.ManagementView
-
Restore redundancy and merge all split segments.
- messageType - Variable in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
- METADATA_SIZE - Static variable in class org.corfudb.infrastructure.log.StreamLogFiles
-
- metadataTypeMap - Static variable in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- metricsReportingSetup(MetricRegistry) - Static method in class org.corfudb.util.MetricsUtils
-
Start metrics reporting via the Dropwizard 'CsvReporter', 'JmxReporter',
and 'Slf4jReporter'.
- MetricsUtils - Class in org.corfudb.util
-
- min(Token, Token) - Static method in class org.corfudb.protocols.wireprotocol.Token
-
Given two tokens return the min
- MonitoringService - Interface in org.corfudb.infrastructure
-
MonitoringService implementations run by the management agent.
- msg() - Method in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
- msgDropAllFilter() - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter which drops all the inbound messages
- msgDropFilterFor(Set<CorfuMsgType>) - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter which checks all inbound messages and
drops them if they are in
- msgDropGaussianFilter(Double) - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter which checks all inbound messages and
using a gaussian (normal) distribution, drops the messages outside the standard
deviation provided by .
- msgDropGaussianFilterFor(Set<CorfuMsgType>, Double) - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter.
- msgDropUniformRandomFilter(Double) - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter which checks all inbound messages and
drops them according to probability .
- msgDropUniformRandomFilterFor(Set<CorfuMsgType>, Double) - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter which checks all inbound messages and
drops messages with types included in with a probability of
.
- msgDuplicateAllFilter() - Static method in class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience method for creating a handling filter which duplicate each of the inbound messages
- msgHandler - Variable in class org.corfudb.runtime.clients.BaseHandler
-
The handler and handlers which implement this client.
- msgHandler - Variable in class org.corfudb.runtime.clients.LayoutHandler
-
The handler and handlers which implement this client.
- msgHandler - Variable in class org.corfudb.runtime.clients.LogUnitHandler
-
The handler and handlers which implement this client.
- msgHandler - Variable in class org.corfudb.runtime.clients.ManagementHandler
-
The handler and handlers which implement this client.
- msgHandler - Variable in class org.corfudb.runtime.clients.SequencerHandler
-
The handler and handlers which implement this client.
- MsgHandlingFilter - Class in org.corfudb.protocols.wireprotocol
-
This class is a representation of a transforming filter, it is composed of a filter
and a list of transforming functions.
- MsgHandlingFilter(Function<CorfuMsg, Boolean>, Function<CorfuMsg, CorfuMsg>) - Constructor for class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
A convenience constructor for when MsgHandlingFilter is being constructed by a filter and
a single transformation function on the message.
- MsgHandlingFilter(Function<CorfuMsg, Boolean>, List<Function<CorfuMsg, CorfuMsg>>) - Constructor for class org.corfudb.protocols.wireprotocol.MsgHandlingFilter
-
Constructing a MsgHandlingFilter.
- MultiCheckpointWriter<T extends Map> - Class in org.corfudb.runtime
-
Checkpoint multiple SMRMaps serially as a prerequisite for a later log trim.
- MultiCheckpointWriter() - Constructor for class org.corfudb.runtime.MultiCheckpointWriter
-
- MultiObjectSMREntry - Class in org.corfudb.protocols.logprotocol
-
Deprecated.
- MultiObjectSMREntry() - Constructor for class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
- MultiObjectSMREntry(Map<UUID, MultiSMREntry>) - Constructor for class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
- MultipleReadRequest - Class in org.corfudb.protocols.wireprotocol
-
A request to read multiple addresses.
- MultipleReadRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.MultipleReadRequest
-
Deserialization Constructor from ByteBuf to ReadRequest.
- MultipleReadRequest(Long) - Constructor for class org.corfudb.protocols.wireprotocol.MultipleReadRequest
-
- MultiReadWriteLock - Class in org.corfudb.infrastructure.log
-
Allows acquiring different read/write locks for different addresses.
- MultiReadWriteLock() - Constructor for class org.corfudb.infrastructure.log.MultiReadWriteLock
-
- MultiReadWriteLock.AutoCloseableLock - Interface in org.corfudb.infrastructure.log
-
- MultiSMREntry - Class in org.corfudb.protocols.logprotocol
-
Deprecated.
- MultiSMREntry() - Constructor for class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- MultiSMREntry(List<SMREntry>) - Constructor for class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- murmerhash3(UUID, long) - Static method in class org.corfudb.util.Utils
-
murmer hash 3 implementation specialized for UUIDs,
based on googlecode C implementation from:
http://smhasher.googlecode.com/svn/trunk/MurmurHash3.cpp
- Mutator - Annotation Type in org.corfudb.annotations
-
Marks a mutator, which is a method on an object
to be recorded in the Corfu log.
- MutatorAccessor - Annotation Type in org.corfudb.annotations
-
Marks a mutatorAccessor, which is an method that modifies the state
of an object, then reads back the result of that modification.
- parallelStream() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- params - Variable in class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
- params - Variable in class org.corfudb.universe.node.server.AbstractCorfuServer
-
- parse(Map<String, Object>) - Static method in class org.corfudb.infrastructure.LogUnitServer.LogUnitServerConfig
-
Parse legacy configuration options
- parse(Map<String, Object>) - Static method in class org.corfudb.infrastructure.SequencerServer.Config
-
- parseConfigurationString(String) - Method in class org.corfudb.runtime.CorfuRuntime
-
Parse a configuration string and get a CorfuRuntime.
- parseLong(Object) - Static method in class org.corfudb.util.Utils
-
A fancy parser which parses suffixes.
- parser - Static variable in class org.corfudb.util.JsonUtils
-
- parseString(String) - Static method in class org.corfudb.util.NodeLocator
-
Parse a node locator string.
- PassThrough - Annotation Type in org.corfudb.annotations
-
Methods marked PassThrough are instrumented,
but call the underlying object directly instead
of syncing or access
Created by mwei on 11/12/16.
- pause() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
Pause a CorfuServer
- pause() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
Pause the container from docker network
- pause() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- pause(String) - Method in class org.corfudb.universe.util.DockerManager
-
Pause a container from the docker network
- payloadMsg(T) - Method in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
- peek(long) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Directly read from the log, returning any
committed value, or NULL, if no value has
been committed.
- peek(RuntimeLayout, long) - Method in class org.corfudb.runtime.view.replication.ChainReplicationProtocol
-
Peek data from a given address.
- peek(RuntimeLayout, long) - Method in interface org.corfudb.runtime.view.replication.IReplicationProtocol
-
Peek data from a given address.
- peek(RuntimeLayout, long) - Method in class org.corfudb.runtime.view.replication.QuorumReplicationProtocol
-
Peek data from a given address.
- peekUntilHoleFillRequired(long, Function<Long, ILogData>) - Method in class org.corfudb.runtime.view.replication.AlwaysHoleFillPolicy
-
Apply the given peek function until hole filling is required or
committed data is returned.
- peekUntilHoleFillRequired(long, Function<Long, ILogData>) - Method in interface org.corfudb.runtime.view.replication.IHoleFillPolicy
-
Apply the given peek function until hole filling is required or
committed data is returned.
- peekUntilHoleFillRequired(long, Function<Long, ILogData>) - Method in class org.corfudb.runtime.view.replication.NeverHoleFillPolicy
-
Apply the given peek function until hole filling is required or
committed data is returned.
- peekUntilHoleFillRequired(long, Function<Long, ILogData>) - Method in class org.corfudb.runtime.view.replication.ReadWaitHoleFillPolicy
-
Apply the given peek function until hole filling is required or
committed data is returned.
- Persistence - Class in org.corfudb.infrastructure.utils
-
Utils class for classes that need to write to the filesystem.
- Persistence() - Constructor for class org.corfudb.infrastructure.utils.Persistence
-
- ping() - Method in class org.corfudb.runtime.clients.BaseClient
-
Ping the endpoint, asynchronously.
- pingSync() - Method in class org.corfudb.runtime.clients.BaseClient
-
Ping the endpoint, synchronously.
- PlainTextCallbackHandler - Class in org.corfudb.security.sasl.plaintext
-
Created by sneginhal on 01/27/2017
- PlainTextCallbackHandler(String, String) - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextCallbackHandler
-
- PlainTextLoginModule - Class in org.corfudb.security.sasl.plaintext
-
Created by sneginhal on 01/27/2017
- PlainTextLoginModule() - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextLoginModule
-
- PlainTextSaslNettyClient - Class in org.corfudb.security.sasl.plaintext
-
Created by sneginhal on 01/31/2017.
- PlainTextSaslNettyClient(String, String) - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextSaslNettyClient
-
Plaintext client constructor.
- PlainTextSaslNettyServer - Class in org.corfudb.security.sasl.plaintext
-
Created by sneginhal on 01/31/2017.
- PlainTextSaslNettyServer() - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextSaslNettyServer
-
- PlainTextSaslServer - Class in org.corfudb.security.sasl.plaintext
-
Created by sneginhal on 01/27/2017.
- PlainTextSaslServer() - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextSaslServer
-
- PlainTextSaslServer.PlainTextSaslServerFactory - Class in org.corfudb.security.sasl.plaintext
-
- PlainTextSaslServerFactory() - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextSaslServer.PlainTextSaslServerFactory
-
- PlainTextSaslServerProvider - Class in org.corfudb.security.sasl.plaintext
-
Created by sneginhal on 01/27/2017.
- PlainTextSaslServerProvider() - Constructor for class org.corfudb.security.sasl.plaintext.PlainTextSaslServerProvider
-
- poll(Layout, CorfuRuntime, SequencerMetrics) - Method in class org.corfudb.infrastructure.management.FailureDetector
-
Executes the policy once.
- poll(Layout, CorfuRuntime, SequencerMetrics) - Method in interface org.corfudb.infrastructure.management.IDetector
-
Executes the detector which runs the failure or healing detecting algorithm.
- pollPeriod - Variable in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
- PollReport - Class in org.corfudb.infrastructure.management
-
Poll Report generated by the detectors that poll to detect failed or healed nodes.
- PollReport() - Constructor for class org.corfudb.infrastructure.management.PollReport
-
- popContext() - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
- populate() - Method in interface org.corfudb.generator.distributions.DataSet
-
Populate the data set.
- populate() - Method in class org.corfudb.generator.distributions.Keys
-
- populate() - Method in class org.corfudb.generator.distributions.OperationCount
-
- populate() - Method in class org.corfudb.generator.distributions.Operations
-
- populate() - Method in class org.corfudb.generator.distributions.Streams
-
- pos() - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- pos() - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- pos() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- predictiveReadRange(Long, List<Long>) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
This method reads a batch of addresses if 'nextRead' is not found in the cache.
- prefixTrim(long) - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- prefixTrim(long) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Prefix trim the global log.
- prefixTrim(long) - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- prefixTrim(Token) - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Send a prefix trim request that will trim the log up to a certain address
- prefixTrim(Token) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Prefix trim the address space.
- prepare(long, long) - Method in class org.corfudb.runtime.clients.LayoutClient
-
Begins phase 1 of a Paxos round with a prepare message.
- prepare(long, long) - Method in class org.corfudb.runtime.view.LayoutView
-
Sends prepare to the current layout and can proceed only if it is accepted by a quorum.
- prettyPrint(String) - Static method in class org.corfudb.util.JsonUtils
-
Return an indented json string.
- previous() - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- previous() - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
Returns the list of SMREntries positioned at the previous log position of this stream.
- previous() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- previous() - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Retrieve the previous entry in the stream.
- previous() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Retrieve the previous entry in the stream.
- previous() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- PRIMITIVE - Static variable in class org.corfudb.util.serializer.Serializers
-
- PrimitiveSerializer - Class in org.corfudb.util.serializer
-
Created by mwei on 2/18/16.
- PrimitiveSerializer(byte) - Constructor for class org.corfudb.util.serializer.PrimitiveSerializer
-
- printByteCode(byte[]) - Static method in class org.corfudb.util.Utils
-
Print byte code.
- printLogAnatomy(CorfuRuntime, ILogData) - Static method in class org.corfudb.util.Utils
-
Print the anatomy of a LogData
- process(Set<? extends TypeElement>, RoundEnvironment) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
- processClass(TypeElement) - Method in class org.corfudb.annotations.ObjectAnnotationProcessor
-
Process each class, checking if the class is annotated and
generating the appropriate proxy class.
- processEntryForContext(ILogData) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Check if the given entry adds a new context, and update
the global pointer.
- ProcessUniverse - Class in org.corfudb.universe.universe.process
-
- ProcessUniverse() - Constructor for class org.corfudb.universe.universe.process.ProcessUniverse
-
- propose(long, long, Layout) - Method in class org.corfudb.runtime.clients.LayoutClient
-
Begins phase 2 of a Paxos round with a propose message.
- propose(long, long, Layout) - Method in class org.corfudb.runtime.view.LayoutView
-
Proposes new layout to all the servers in the current layout.
- pushNewContext(UUID, long) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Add a new context.
- put(Class<T>, String, String, T) - Method in class org.corfudb.infrastructure.DataStore
-
- put(IDataStore.KvRecord<T>, T) - Method in class org.corfudb.infrastructure.DataStore
-
- put(Class<T>, String, String, T) - Method in interface org.corfudb.infrastructure.IDataStore
-
Deprecated.
- put(IDataStore.KvRecord<T>, T) - Method in interface org.corfudb.infrastructure.IDataStore
-
Stores a value for a key under a prefix (namespace).
- put(SequencerServerCache.ConflictTxStream, long) - Method in class org.corfudb.infrastructure.SequencerServerCache
-
Put a value in the cache
- put(Long, LogData) - Method in class org.corfudb.protocols.wireprotocol.ReadResponse
-
- put(K, V) - Method in class org.corfudb.runtime.collections.CorfuTable
- put(K, V) - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Associates the specified value with the specified key in this map
(optional operation).
- put(K, V) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- putAll(Map<? extends K, ? extends V>) - Method in class org.corfudb.runtime.collections.CorfuTable
- putAll(Map<? extends K, ? extends V>) - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Copies all of the mappings from the specified map to this map
(optional operation).
- putAll(Map<? extends K, ? extends V>) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- putAllConflictFunction(Map<? extends K, ? extends V>) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
Generate the conflict parameters for putAll, given the arguments to the
putAll operation.
- putIfAbsent(K, V) - Method in class org.corfudb.runtime.collections.CorfuTable
- putIfAbsent(K, V) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
If the specified key is not already associated with a value (or is mapped
to null
) associates it with the given value and returns
null
, else returns the current value.
- rand - Variable in class org.corfudb.generator.State
-
- rangeFromBuffer(ByteBuf, Class<V>) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
A really simple flat set implementation.
- rangeSetFromBuffer(ByteBuf, Class<V>) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
A really simple flat set implementation.
- rangeWrite(CorfuPayloadMsg<RangeWriteMsg>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.LogUnitServer
-
Services incoming range write calls.
- RangeWriteMsg - Class in org.corfudb.protocols.wireprotocol
-
A sequence of log entries to write
- RangeWriteMsg(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.RangeWriteMsg
-
- Rank - Class in org.corfudb.infrastructure
-
Tuple to store the rank and clientId for each round in Paxos.
- Rank() - Constructor for class org.corfudb.infrastructure.Rank
-
- rank - Variable in class org.corfudb.protocols.wireprotocol.IMetadata.DataRank
-
- reachable - Variable in exception org.corfudb.runtime.exceptions.QuorumUnreachableException
-
- read(long) - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- read(long) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Given an address, read the corresponding stream entry.
- read(long) - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- read(long) - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Asynchronously read from the logging unit.
- read(long) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Read the given object from an address and streams.
- read(Iterable<Long>) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Read the given object from a range of addresses.
- read(Iterable<Long>, boolean) - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Read the given object from a range of addresses.
- read(RuntimeLayout, long) - Method in class org.corfudb.runtime.view.replication.AbstractReplicationProtocol
-
Read data from a given address.
- read(RuntimeLayout, long) - Method in interface org.corfudb.runtime.view.replication.IReplicationProtocol
-
Read data from a given address.
- read(long, long) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Reads data from an address in the address space.
- read(long) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
- readAll(List<Long>) - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Read data from the log unit server for a list of addresses.
- readAll(RuntimeLayout, List<Long>, boolean) - Method in class org.corfudb.runtime.view.replication.ChainReplicationProtocol
-
Reads a list of global addresses from the chain of log unit servers.
- readAll(RuntimeLayout, List<Long>, boolean) - Method in interface org.corfudb.runtime.view.replication.IReplicationProtocol
-
Read data from all the given addresses.
- readAll(RuntimeLayout, List<Long>, boolean) - Method in class org.corfudb.runtime.view.replication.QuorumReplicationProtocol
-
Read data from all the given addresses.
- readAll(List<Long>) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
- readLock() - Method in class org.corfudb.util.LockUtils.AutoCloseRwLock
-
Acquire read lock.
- ReadOperation - Class in org.corfudb.generator.operations
-
Created by maithem on 7/14/17.
- ReadOperation(State) - Constructor for class org.corfudb.generator.operations.ReadOperation
-
- readRange(long, List<Long>) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
- ReadRequest - Class in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/11/16.
- ReadRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.ReadRequest
-
Deserialization Constructor from ByteBuf to ReadRequest.
- ReadResponse - Class in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/15/16.
- ReadResponse(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.ReadResponse
-
- ReadResponse() - Constructor for class org.corfudb.protocols.wireprotocol.ReadResponse
-
- ReadWaitHoleFillPolicy - Class in org.corfudb.runtime.view.replication
-
A hole filling policy which reads several times,
waiting a static amount of time in between, before
requiring a hole fill.
- ReadWaitHoleFillPolicy(Duration, Duration) - Constructor for class org.corfudb.runtime.view.replication.ReadWaitHoleFillPolicy
-
Create a ReadWaitHoleFillPolicy with the given wait times
and retries.
- READY - Static variable in class org.corfudb.protocols.wireprotocol.SequencerMetrics
-
- RebootUtil - Class in org.corfudb.runtime
-
Utility to Reboot a server which includes reset or restart
Reset wipes out all existing Corfu data while restart does not.
- ReconfigurationEventHandler - Class in org.corfudb.infrastructure.management
-
The ReconfigurationEventHandler handles the trigger provided by any source
or policy detecting a failure or healing in the cluster.
- ReconfigurationEventHandler() - Constructor for class org.corfudb.infrastructure.management.ReconfigurationEventHandler
-
- reconfigureSequencerServers(Layout, Layout, boolean) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Reconfigures the sequencer.
- reconnect() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- reconnect(List<CorfuServer>) - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- reconnect() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
Reconnect a server to the cluster
- reconnect(List<CorfuServer>) - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
Reconnect a server to a list of servers.
- reconnect() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
Reconnect a server to the cluster
- reconnect(List<CorfuServer>) - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
Reconnect a server to a list of servers.
- recordOperation(String, boolean) - Static method in class org.corfudb.generator.Correctness
-
- RECORDS_PER_LOG_FILE - Static variable in class org.corfudb.infrastructure.log.StreamLogFiles
-
- recordTransactionMarkers(boolean, String...) - Static method in class org.corfudb.generator.Correctness
-
Record a transaction marker operation
- RecoveryException - Exception in org.corfudb.runtime.exceptions
-
Created by mwei on 4/7/17.
- RecoveryException(String) - Constructor for exception org.corfudb.runtime.exceptions.RecoveryException
-
- RecoveryUtils - Class in org.corfudb.recovery
-
Created by rmichoud on 6/22/17.
- ReflectionUtils - Class in org.corfudb.util
-
Created by mwei on 3/29/16.
- refreshClusterView(Layout, PollReport) - Method in class org.corfudb.infrastructure.management.ClusterStateContext
-
Refreshes the cluster view based on the local endpoint and the snapshot epoch at which the
node states are updated.
- registerBeforeRpcHandler(Runnable) - Method in class org.corfudb.runtime.CorfuRuntime
-
Deprecated.
- registerCustomHasher(Class<T>, Function<T, byte[]>) - Method in interface org.corfudb.util.serializer.ISerializer
-
Register a new custom hasher with the serializer.
- registerSerializer(ISerializer) - Static method in class org.corfudb.util.serializer.Serializers
-
Register a serializer.
- registerSystemDownHandler(Runnable) - Method in class org.corfudb.runtime.CorfuRuntime
-
Deprecated.
- release() - Method in class org.corfudb.protocols.wireprotocol.CorfuMsg
-
Release the underlying buffer, if present.
- releaseBuffer() - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- releaseBuffer() - Method in class org.corfudb.protocols.wireprotocol.LogData
-
- releaseStress() - Method in interface org.corfudb.universe.node.stress.Stress
-
To release the existing stress load on a node.
- releaseStress() - Method in class org.corfudb.universe.node.stress.vm.VmStress
-
To release the existing stress load on
CorfuServer
node.
- ReloadableTrustManager - Class in org.corfudb.security.tls
-
This trust manager reloads the trust store whenever a checkClientTrusted
or checkServerTrusted is called.
- ReloadableTrustManager(String, String) - Constructor for class org.corfudb.security.tls.ReloadableTrustManager
-
Constructor.
- ReloadableTrustManagerFactory - Class in org.corfudb.security.tls
-
A trust manager factory that returns a ReloadableTrustManager.
- ReloadableTrustManagerFactory(String, String) - Constructor for class org.corfudb.security.tls.ReloadableTrustManagerFactory
-
Constructor.
- remaining() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Retrieve all of the entries from this stream, up to the tail of this
stream.
- remainingUpTo(long) - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- remainingUpTo(long) - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
Returns all entries remaining upto the specified the global address specified.
- remainingUpTo(long) - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- remainingUpTo(long) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Retrieve all of the entries from this stream, up to the address given or
the tail of the stream.
- remainingUpTo(long) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Retrieve all of the entries from this stream, up to the address given or
the tail of the stream.
- remainingUpTo(long) - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- RemoteMonitoringService - Class in org.corfudb.infrastructure
-
Remote Monitoring Service constitutes of failure and healing monitoring and handling.
- RemoteMonitoringService.DetectorTask - Enum in org.corfudb.infrastructure
-
- RemoteOperationHelper - Class in org.corfudb.universe.group.cluster.vm
-
Provides the helper functions that do operations (copy file/execute command) on a remote machine.
- remoteOriginUrl - Variable in class org.corfudb.util.GitRepositoryState
-
- remove(Object) - Method in class org.corfudb.runtime.collections.CorfuTable
- remove(Object, Object) - Method in class org.corfudb.runtime.collections.CorfuTable
- remove(Object) - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Removes the mapping for a key from this map if it is present
(optional operation).
- remove(Object) - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- remove(Object, Object) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Removes the entry for the specified key only if it is currently
mapped to the specified value.
- remove(Object) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- removeAddresses(List<Long>) - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Remove addresses from the stream's address map
and set the new trim mark (to the greatest of all addresses to remove).
- removeAll(Collection<?>) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- removeContext() - Static method in class org.corfudb.runtime.object.transactions.TransactionalContext
-
Remove the most recent transaction context from the transaction stack.
- removeFromQueue(NavigableSet<Long>) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
Remove next entry from the queue.
- removeFromQueue(NavigableSet<Long>) - Method in class org.corfudb.runtime.view.stream.AddressMapStreamView
-
- removeFromQueue(NavigableSet<Long>) - Method in class org.corfudb.runtime.view.stream.BackpointerStreamView
-
- removeFromStripe(String, Layout.LayoutStripe, int) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Remove an endpoint from a segment.
- removeIf(Predicate<? super E>) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- removeLayoutServer(String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes the Layout Server passed.
- removeLayoutServers(Set<String>) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes all the Layout Server endpoints present in the set passed.
- removeLogunitServer(String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes the Log unit endpoint from the layout.
- removeLogunitServers(Set<String>) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes the Log unit endpoints from the layout.
- removeNode(String) - Method in class org.corfudb.runtime.clients.ManagementClient
-
Return a workflow id for this remove operation request.
- removeNode(Layout, String) - Method in class org.corfudb.runtime.view.LayoutManagementView
-
Best effort attempt to removes a node from the layout.
- removeNode(String, int, Duration, Duration) - Method in class org.corfudb.runtime.view.ManagementView
-
Remove a node from the cluster.
- RemoveNode - Class in org.corfudb.runtime.view.workflows
-
A workflow request that makes an orchestrator call to remove a node from
the cluster.
- RemoveNode(String, CorfuRuntime, int, Duration, Duration) - Constructor for class org.corfudb.runtime.view.workflows.RemoveNode
-
- RemoveNodeRequest - Class in org.corfudb.protocols.wireprotocol.orchestrator
-
An orchestrator request to remove a node to the cluster.
- RemoveNodeRequest(String) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.RemoveNodeRequest
-
Creates a request to remove a node from an endpoint.
- RemoveNodeRequest(byte[]) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.RemoveNodeRequest
-
Create a remove node request from a byte buffer
- RemoveNodeWorkflow - Class in org.corfudb.infrastructure.orchestrator.workflows
-
A workflow definition that removes a node from the cluster, if it exists.
- RemoveNodeWorkflow(RemoveNodeRequest) - Constructor for class org.corfudb.infrastructure.orchestrator.workflows.RemoveNodeWorkflow
-
Create a remove node workflow from a request.
- RemoveOperation - Class in org.corfudb.generator.operations
-
Created by maithem on 7/14/17.
- RemoveOperation(State) - Constructor for class org.corfudb.generator.operations.RemoveOperation
-
- removeSequencerServer(String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes the Sequencer Server passed.
- removeSequencerServers(Set<String>) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes all the Sequencer Server endpoints present in the set passed.
- removeUnresponsiveServer(String) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes a server from layout's list of unresponsive servers.
- removeUnresponsiveServers(Set<String>) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Removes unresponsive servers.
- replace(K, V) - Method in class org.corfudb.runtime.collections.CorfuTable
- replace(K, V, V) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Replaces the entry for the specified key only if currently
mapped to the specified value.
- replace(K, V) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Replaces the entry for the specified key only if it is
currently mapped to some value.
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.CorfuTable
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Replaces each entry's value with the result of invoking the given
function on that entry until all entries have been processed or the
function throws an exception.
- request - Variable in class org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorMsg
-
- Request - Interface in org.corfudb.protocols.wireprotocol.orchestrator
-
An interface that should be implemented by all the orchestrator service requests.
- requestID - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
Deprecated.
- requestMetrics() - Method in class org.corfudb.runtime.clients.SequencerClient
-
Sends a metrics request to the sequencer server.
- required - Variable in exception org.corfudb.runtime.exceptions.QuorumUnreachableException
-
- reset() - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- reset() - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Clears all data and resets all segment handlers.
- reset() - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
TODO(Maithem) remove this method.
- reset() - Method in class org.corfudb.runtime.clients.BaseClient
-
Reset the endpoint, asynchronously.
- reset() - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- reset() - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- reset() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- reset(String, int, Duration) - Static method in class org.corfudb.runtime.RebootUtil
-
Resets the given server.
- reset(String, CorfuRuntime.CorfuRuntimeParameters, int, Duration) - Static method in class org.corfudb.runtime.RebootUtil
-
Resets the given server.
- reset() - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Reset the state of this stream view, causing the next read to
start from the beginning of this stream.
- reset() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Reset the state of this stream view, causing the next read to
start from the beginning of this stream.
- reset() - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- resetCaches() - Method in class org.corfudb.runtime.view.AddressSpaceView
-
Reset all in-memory caches.
- resetLogUnit(long) - Method in class org.corfudb.runtime.clients.LogUnitClient
-
Send a reset request.
- resetServer(CorfuPayloadMsg<SequencerRecoveryMsg>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.SequencerServer
-
Service an incoming request to reset the sequencer.
- resetStartingAddress() - Method in class org.corfudb.infrastructure.log.StreamLogDataStore
-
Reset starting address
- resetTailSegment() - Method in class org.corfudb.infrastructure.log.StreamLogDataStore
-
Reset tail segment
- resetUnsafe() - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Reset this object to the uninitialized state.
- resolveCheckpoint(AbstractQueuedStreamView.QueuedStreamContext, ILogData, long) - Method in class org.corfudb.runtime.view.stream.AbstractQueuedStreamView
-
- response - Variable in class org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorResponse
-
- Response - Interface in org.corfudb.protocols.wireprotocol.orchestrator
-
An interface that should be implemented by all the orchestrator service responses.
- restart() - Method in class org.corfudb.runtime.clients.BaseClient
-
Restart the endpoint, asynchronously.
- restart(String, int, Duration) - Static method in class org.corfudb.runtime.RebootUtil
-
Restarts the given server.
- restart(String, CorfuRuntime.CorfuRuntimeParameters, int, Duration) - Static method in class org.corfudb.runtime.RebootUtil
-
Restarts the given server.
- restart() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- restart() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
- restart() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- restart(String) - Method in class org.corfudb.universe.util.DockerManager
-
Restart a docker container
- restartServer(ServerContext, boolean) - Static method in class org.corfudb.infrastructure.CorfuServer
-
Cleanly shuts down the server and restarts.
- RestoreRedundancy() - Constructor for class org.corfudb.infrastructure.orchestrator.workflows.AddNodeWorkflow.RestoreRedundancy
-
- RestoreRedundancyMergeSegments - Class in org.corfudb.infrastructure.orchestrator.actions
-
This action attempts to restore redundancy for all servers across all segments
starting from the oldest segment.
- RestoreRedundancyMergeSegments() - Constructor for class org.corfudb.infrastructure.orchestrator.actions.RestoreRedundancyMergeSegments
-
- RestoreRedundancyMergeSegments - Class in org.corfudb.runtime.view.workflows
-
Sending a workflow request to restore all redundancies and merge all segments.
- RestoreRedundancyMergeSegments(String, CorfuRuntime, int, Duration, Duration) - Constructor for class org.corfudb.runtime.view.workflows.RestoreRedundancyMergeSegments
-
Create a Merge segments workflow request.
- RestoreRedundancyMergeSegmentsRequest - Class in org.corfudb.protocols.wireprotocol.orchestrator
-
An orchestrator request message to restore redundancy and merge all segments in the cluster.
- RestoreRedundancyMergeSegmentsRequest(String) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.RestoreRedundancyMergeSegmentsRequest
-
- RestoreRedundancyMergeSegmentsRequest(byte[]) - Constructor for class org.corfudb.protocols.wireprotocol.orchestrator.RestoreRedundancyMergeSegmentsRequest
-
- RestoreRedundancyMergeSegmentsWorkflow - Class in org.corfudb.infrastructure.orchestrator.workflows
-
A definition of a workflow that merges all the segments in the layout.
- RestoreRedundancyMergeSegmentsWorkflow(RestoreRedundancyMergeSegmentsRequest) - Constructor for class org.corfudb.infrastructure.orchestrator.workflows.RestoreRedundancyMergeSegmentsWorkflow
-
Creates a new merge segments workflow from a request.
- resume() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- resume() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
- resume() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- resume(String) - Method in class org.corfudb.universe.util.DockerManager
-
Resume a docker container
- retainAll(Collection<?>) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- retry - Variable in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
- RetryExhaustedException - Exception in org.corfudb.runtime.exceptions
-
RetryExhaustedException is thrown when there is no hope in retrying and the current progress
needs to be aborted.
- RetryExhaustedException(String) - Constructor for exception org.corfudb.runtime.exceptions.RetryExhaustedException
-
- retryFunction() - Method in interface org.corfudb.util.retry.IRetryable
-
Returns true on success, false will cause retry.
- RetryNeededException - Exception in org.corfudb.util.retry
-
Exception that must be thrown explicitly from the executed function when a retry is needed.
- RetryNeededException() - Constructor for exception org.corfudb.util.retry.RetryNeededException
-
- revertDropInput(String) - Static method in class org.corfudb.universe.util.IpTablesUtil
-
Recover the drop input rule
- revertDropOutput(String) - Static method in class org.corfudb.universe.util.IpTablesUtil
-
Recover the drop input rule
- rollbackObjectUnsafe(long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Roll the object back to the supplied version if possible.
- rollbackStreamUnsafe(ISMRStream, long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Roll back the given stream by applying undo records in reverse order
from the current stream position until rollbackVersion.
- router - Variable in class org.corfudb.runtime.clients.BaseHandler
-
The router to use for the client.
- run() - Method in interface org.corfudb.util.retry.IRetry
-
Run the retry.
- runAfter(Duration, Runnable) - Static method in class org.corfudb.util.CFUtils
-
Schedules a runnable after a given time
- runLongevityTest() - Method in class org.corfudb.generator.LongevityApp
-
- runRuntimeGC() - Method in class org.corfudb.runtime.ViewsGarbageCollector
-
Over time garbage is created on the global log and clients sync
parts of the log therefore clients can accumulate garbage overtime.
- runSansThrow(Runnable) - Static method in class org.corfudb.util.LambdaUtils
-
Suppresses all exceptions.
- runtime - Variable in class org.corfudb.protocols.logprotocol.LogEntry
-
The runtime to use.
- runtime - Variable in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
- RuntimeLayout - Class in org.corfudb.runtime.view
-
This is a wrapper over the layout to provide the clients required to communicate with the nodes.
- RuntimeLayout(Layout, CorfuRuntime) - Constructor for class org.corfudb.runtime.view.RuntimeLayout
-
Constructor taking a reference of the layout to stamp the clients.
- sample(int) - Method in interface org.corfudb.generator.distributions.DataSet
-
Returns a random subset of the data.
- sample(int) - Method in class org.corfudb.generator.distributions.OperationCount
-
- SaslUtils - Class in org.corfudb.security.sasl
-
Created by sneginhal on 02/01/2017.
- saveFailureDetectorMetrics(FailureDetectorMetrics) - Method in class org.corfudb.infrastructure.ServerContext
-
Save detected failure in a history.
- saveManagementLayout(Layout) - Method in class org.corfudb.infrastructure.ServerContext
-
Sets the management layout in the persistent datastore.
- scanAndFilter(Predicate<? super V>) - Method in class org.corfudb.runtime.collections.CorfuTable
-
Returns a filtered
List
view of the values contained in this map.
- scanAndFilter(Predicate<? super V>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Returns a filtered
List
view of the values contained in this map.
- scanAndFilterByEntry(Predicate<? super Map.Entry<K, V>>) - Method in class org.corfudb.runtime.collections.CorfuTable
-
Returns a
Collection
filtered by entries (keys and/or values).
- scanAndFilterByEntry(Predicate<? super Map.Entry<K, V>>) - Method in interface org.corfudb.runtime.collections.ICorfuMap
-
Returns a
Collection
filtered by entries (keys and/or values).
- scanAndFilterByEntry(Predicate<? super Map.Entry<K, V>>) - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Returns a
Collection
filtered by entries (keys and/or values).
- Scenario<D,T extends Fixture<D>> - Class in org.corfudb.universe.scenario
-
Scenario is testing Api.
- Scenario.ScenarioTest<T,R> - Class in org.corfudb.universe.scenario
-
Scenario test execute an action and then check the result by a spec.
- Scenario.ScenarioTestCase<T> - Class in org.corfudb.universe.scenario
-
ScenarioTestCase is a ScenarioTest-s factory, represents a group of tests.
- ScenarioTest(T, Action<R>, String) - Constructor for class org.corfudb.universe.scenario.Scenario.ScenarioTest
-
- ScenarioTestCase(T) - Constructor for class org.corfudb.universe.scenario.Scenario.ScenarioTestCase
-
- sealMinServerSet() - Method in class org.corfudb.runtime.view.RuntimeLayout
-
Attempts to move all servers in the system to the epoch of this layout.
- SealServersHelper - Class in org.corfudb.runtime.view
-
Helper class to seal requested servers.
- SealServersHelper() - Constructor for class org.corfudb.runtime.view.SealServersHelper
-
- sealServerWithEpoch(long) - Method in class org.corfudb.infrastructure.AbstractServer
-
Seal the server with the epoch.
- sealServerWithEpoch(long) - Method in class org.corfudb.infrastructure.LogUnitServer
-
Seal the server with the epoch.
- seek(long) - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- seek(long) - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- seek(long) - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- seek(long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Move the pointer for this object (effectively, forcefuly
change the version of this object without playing
any updates).
- seek(long) - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
Seek to the requested maxGlobal address.
- seek(long) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Seek to the requested maxGlobal address.
- seek(long) - Method in class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- sendFailureDetectorMetricsRequest() - Method in class org.corfudb.runtime.clients.ManagementClient
-
- sendMessage(ChannelHandlerContext, CorfuMsg) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Send a one way message, without adding a completable future.
- sendMessage(CorfuMsg) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Send a one way message using the default channel handler,
without adding a completable future.
- sendMessage(ChannelHandlerContext, CorfuMsg) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Send a one way message, without adding a completable future.
- sendMessageAndGetCompletable(ChannelHandlerContext, CorfuMsg) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Send a message and get a completable future to be fulfilled by the reply.
- sendMessageAndGetCompletable(CorfuMsg) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Send a message using the router channel handler and
get a completable future to be fulfilled by the reply.
- sendMessageAndGetCompletable(ChannelHandlerContext, CorfuMsg) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Send a message and get a completable future to be fulfilled by the reply.
- sendNodeStateRequest() - Method in class org.corfudb.runtime.clients.ManagementClient
-
- sendRequest(ManagementClient) - Method in class org.corfudb.runtime.view.workflows.AddNode
-
- sendRequest(ManagementClient) - Method in class org.corfudb.runtime.view.workflows.ForceRemoveNode
-
- sendRequest(ManagementClient) - Method in class org.corfudb.runtime.view.workflows.HealNode
-
- sendRequest(ManagementClient) - Method in class org.corfudb.runtime.view.workflows.RemoveNode
-
- sendRequest(ManagementClient) - Method in class org.corfudb.runtime.view.workflows.RestoreRedundancyMergeSegments
-
Creates and sends the workflow request to restore redundancy and merge the segments.
- sendRequest(ManagementClient) - Method in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
Send a workflow request
- sendResponse(ChannelHandlerContext, CorfuMsg, CorfuMsg) - Method in interface org.corfudb.infrastructure.IServerRouter
-
- sendResponse(ChannelHandlerContext, CorfuMsg, CorfuMsg) - Method in class org.corfudb.infrastructure.NettyServerRouter
-
Send a netty message through this router, setting the fields in the outgoing message.
- sendResponseToServer(ChannelHandlerContext, CorfuMsg, CorfuMsg) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Send a netty message through this router, setting the fields in the outgoing message.
- sendResponseToServer(ChannelHandlerContext, CorfuMsg, CorfuMsg) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Send a netty message through this router, setting the fields in the outgoing message.
- SequencerClient - Class in org.corfudb.runtime.clients
-
A sequencer client.
- SequencerClient(IClientRouter, long) - Constructor for class org.corfudb.runtime.clients.SequencerClient
-
- SequencerHandler - Class in org.corfudb.runtime.clients
-
A sequencer handler client.
- SequencerHandler() - Constructor for class org.corfudb.runtime.clients.SequencerHandler
-
- SequencerMetrics - Class in org.corfudb.protocols.wireprotocol
-
Sequencer metrics for a node.
- SequencerMetrics(SequencerMetrics.SequencerStatus) - Constructor for class org.corfudb.protocols.wireprotocol.SequencerMetrics
-
- SequencerMetrics(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.SequencerMetrics
-
- SequencerMetrics.SequencerStatus - Enum in org.corfudb.protocols.wireprotocol
-
- SequencerRecoveryMsg - Class in org.corfudb.protocols.wireprotocol
-
Created by rmichoud on 6/20/17.
- SequencerRecoveryMsg(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.SequencerRecoveryMsg
-
- SequencerServer - Class in org.corfudb.infrastructure
-
This server implements the sequencer functionality of Corfu.
- SequencerServer(ServerContext) - Constructor for class org.corfudb.infrastructure.SequencerServer
-
Returns a new SequencerServer.
- SequencerServer.Config - Class in org.corfudb.infrastructure
-
Sequencer server configuration
- SequencerServerCache - Class in org.corfudb.infrastructure
-
Sequencer server cache.
- SequencerServerCache(long, CacheWriter<SequencerServerCache.ConflictTxStream, Long>) - Constructor for class org.corfudb.infrastructure.SequencerServerCache
-
- SequencerServerCache(long) - Constructor for class org.corfudb.infrastructure.SequencerServerCache
-
The cache limited by size.
- SequencerServerCache.ConflictTxStream - Class in org.corfudb.infrastructure
-
Contains the conflict hash code for a stream ID and conflict param.
- SequencerView - Class in org.corfudb.runtime.view
-
Created by mwei on 12/10/15.
- SequencerView(CorfuRuntime) - Constructor for class org.corfudb.runtime.view.SequencerView
-
- SerializationFailedException(Class<? extends Throwable>) - Constructor for exception org.corfudb.protocols.wireprotocol.ExceptionMsg.SerializationFailedException
-
Constructor for SerializationFailedException.
- SerializationHandle(ILogData) - Constructor for class org.corfudb.protocols.wireprotocol.ILogData.SerializationHandle
-
Create a new serialized handle with a reference
to the log data.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.logprotocol.CheckpointEntry
-
Serialize the given LogEntry into a given byte buffer.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.logprotocol.LogEntry
-
Serialize the given LogEntry into a given byte buffer.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.CorfuMsg
-
Serialize the message into the given bytebuffer.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.CorfuPayloadMsg
-
Serialize the message into the given bytebuffer.
- serialize(ByteBuf, T) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
Serialize a payload into a given byte buffer.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.JSONPayloadMsg
-
Serialize the message into the given bytebuffer.
- serialize(ByteBuf) - Method in class org.corfudb.protocols.wireprotocol.LayoutMsg
-
Serialize the message into the given bytebuffer.
- serialize(Object, ByteBuf) - Method in class org.corfudb.util.serializer.CorfuSerializer
-
Serialize an object into a given byte buffer.
- serialize(ByteBuf) - Method in interface org.corfudb.util.serializer.ICorfuSerializable
-
- serialize(Object, ByteBuf) - Method in interface org.corfudb.util.serializer.ISerializer
-
Serialize an object into a given byte buffer.
- serialize(Object, ByteBuf) - Method in class org.corfudb.util.serializer.JavaSerializer
-
Serialize an object into a given byte buffer.
- serialize(Object, ByteBuf) - Method in class org.corfudb.util.serializer.JsonSerializer
-
Serialize an object into a given byte buffer.
- serialize(Object, ByteBuf) - Method in class org.corfudb.util.serializer.PrimitiveSerializer
-
Serialize an object into a given byte buffer.
- serialize(Object) - Static method in class org.corfudb.util.Utils
-
Serialize an object into a ByteBuffer.
- SerializerException - Exception in org.corfudb.runtime.exceptions
-
Created by annym on 04/12/19
- SerializerException(Byte) - Constructor for exception org.corfudb.runtime.exceptions.SerializerException
-
Constructor for SerializerException specifying serializer type.
- SerializerException(String) - Constructor for exception org.corfudb.runtime.exceptions.SerializerException
-
Constructor for SerializerException specifying exception message.
- SerializerMap - Static variable in class org.corfudb.util.serializer.PrimitiveSerializer
-
- Serializers - Class in org.corfudb.util.serializer
-
Created by mwei on 1/8/16.
- Serializers() - Constructor for class org.corfudb.util.serializer.Serializers
-
- ServerContext - Class in org.corfudb.infrastructure
-
Server Context:
Contains the common node level
DataStore
Responsible for Server level EPOCH
Should contain common services/utilities that the different Servers in a node require.
- ServerContext(Map<String, Object>) - Constructor for class org.corfudb.infrastructure.ServerContext
-
Returns a new ServerContext.
- ServerHandler - Annotation Type in org.corfudb.infrastructure
-
Created by mwei on 8/8/16.
- ServerHandshakeHandler - Class in org.corfudb.infrastructure
-
The ServerHandshakeHandler waits for the handshake message, validates and sends
a response to the client.
- ServerHandshakeHandler(UUID, String, String) - Constructor for class org.corfudb.infrastructure.ServerHandshakeHandler
-
Creates a new ServerHandshakeHandler which will handle the handshake--initiated by a client
on the server side.
- ServerNotReadyException - Exception in org.corfudb.runtime.exceptions
-
Created by zlokhandwala on 6/26/17.
- ServerNotReadyException() - Constructor for exception org.corfudb.runtime.exceptions.ServerNotReadyException
-
- servers - Variable in class org.corfudb.universe.scenario.fixture.Fixtures.AbstractUniverseFixture
-
- ServerThreadFactory - Class in org.corfudb.infrastructure
-
- ServerThreadFactory(String, Thread.UncaughtExceptionHandler) - Constructor for class org.corfudb.infrastructure.ServerThreadFactory
-
- ServerThreadFactory.ExceptionHandler - Class in org.corfudb.infrastructure
-
- ServerUtil - Class in org.corfudb.universe.node.server
-
- set(boolean, boolean) - Method in class org.corfudb.protocols.wireprotocol.HandshakeState
-
Set Handshake State
- set(CorfuCompoundObject.Inner, int) - Method in class org.corfudb.samples.CorfuCompoundObject
-
- Set(int) - Method in class org.corfudb.samples.CorfuSharedCounter
-
Set() method is annotates as a Mutator method.
- setArguments(Object...) - Method in class org.corfudb.runtime.view.ObjectBuilder
-
- setArgumentsArray(Object[]) - Method in class org.corfudb.runtime.view.ObjectBuilder
-
- setBackpointerMap(Map<UUID, Long>) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setBackpointersDisabled(boolean) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setBulkReadSize(int) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setCacheDisabled(boolean) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setCacheExpiryTime(int) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setCheckpointedStreamId(UUID) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setCheckpointedStreamStartLogAddress(Long) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setCheckpointId(UUID) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setCheckpointType(CheckpointEntry.CheckpointEntryType) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setClientId(UUID) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setCommit() - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setCorfuSMRProxy(ICorfuSMRProxy<T>) - Method in interface org.corfudb.runtime.object.ICorfuSMR
-
Set the proxy for this wrapper, to manage the state of the object.
- setCurrentLayout(Layout) - Method in class org.corfudb.infrastructure.LayoutServer
-
Sets the current layout in context DataStore.
- setCurrentLayout(Layout) - Method in class org.corfudb.infrastructure.ServerContext
-
- setEntry(ILogData) - Method in class org.corfudb.protocols.logprotocol.MultiObjectSMREntry
-
Deprecated.
- setEntry(ILogData) - Method in class org.corfudb.protocols.logprotocol.MultiSMREntry
-
Deprecated.
- setEpoch(Long) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setEpoch(long) - Method in class org.corfudb.runtime.view.LayoutBuilder
-
Set layout's epoch
- setFromBuffer(ByteBuf, Class<V>) - Static method in interface org.corfudb.protocols.wireprotocol.ICorfuPayload
-
A really simple flat set implementation.
- setGlobalAddress(Long) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setGlobalPointer(long) - Method in class org.corfudb.runtime.view.stream.AbstractStreamContext
-
- setGlobalPointerCheckGCTrimMark(long) - Method in class org.corfudb.runtime.view.stream.AbstractStreamContext
-
Set Global Pointer and validate its position does not fall in the GC trim range.
- setHoleFillingDisabled(boolean) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setId(UUID) - Method in interface org.corfudb.protocols.wireprotocol.ILogData
-
- setLayoutInHistory(Layout) - Method in class org.corfudb.infrastructure.LayoutServer
-
- setLayoutInHistory(Layout) - Method in class org.corfudb.infrastructure.ServerContext
-
- setLoadSmrMapsAtConnect(boolean) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setLogUnitEpochWaterMark(long) - Method in class org.corfudb.infrastructure.ServerContext
-
Sets the log unit epoch water mark.
- setNumCacheEntries(long) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setOptimisticStreamUnsafe(WriteSetSMRStream) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Set the optimistic stream for this thread, rolling back
any previous threads if they were present.
- setOptions(Consumer<A>) - Method in interface org.corfudb.util.retry.IRetry
-
Configure settings for the underlying class.
- setPhase1Rank(Rank) - Method in class org.corfudb.infrastructure.LayoutServer
-
- setPhase1Rank(Rank) - Method in class org.corfudb.infrastructure.ServerContext
-
- setPhase2Data(Phase2Data) - Method in class org.corfudb.infrastructure.LayoutServer
-
- setPhase2Data(Phase2Data) - Method in class org.corfudb.infrastructure.ServerContext
-
- setProxy$CORFUSMR(ICorfuSMRProxy<T>) - Method in class org.corfudb.runtime.object.AbstractCorfuWrapper
-
- setProxy$CORFUSMR(ICorfuSMRProxy<T>) - Method in interface org.corfudb.runtime.object.ICorfuSMRProxyWrapper
-
Set the proxy.
- setRank(IMetadata.DataRank) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
Set the rank of this append.
- setRemoteEpoch(long) - Method in class org.corfudb.runtime.clients.BaseClient
-
Sets the epoch on client router and on the target layout server.
- setRouter(IClientRouter) - Method in interface org.corfudb.runtime.clients.IClient
-
Set the router used by the Netty client.
- setSequencerEpoch(long) - Method in class org.corfudb.infrastructure.ServerContext
-
Persists the sequencer epoch.
- setServerEpoch(long) - Method in interface org.corfudb.infrastructure.IServerRouter
-
Set the current epoch.
- setServerEpoch(long, IServerRouter) - Method in class org.corfudb.infrastructure.ServerContext
-
Set the serverRouter epoch.
- setState(AbstractServer.ServerState) - Method in class org.corfudb.infrastructure.AbstractServer
-
- setStreamID(UUID) - Method in interface org.corfudb.runtime.object.IObjectBuilder
-
Set the stream ID of the object.
- setStreamName(String) - Method in interface org.corfudb.runtime.object.IObjectBuilder
-
Set the name of the stream for this object.
- setThreadId(Long) - Method in interface org.corfudb.protocols.wireprotocol.IMetadata
-
- setTimeoutConnect(long) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Set the Connect timeout
- setTimeoutInMinutesForFastLoading(int) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setTimeoutResponse(long) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Set the Response timeout
- setTimeoutRetry(long) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Set the retry timeout
- setTransactionLogging(boolean) - Method in class org.corfudb.runtime.CorfuRuntime
-
If enabled, successful transactions will be written to a special transaction stream
(i.e.
- setTrimMark(long) - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
- setTrimRetry(int) - Method in class org.corfudb.runtime.CorfuRuntime
-
- setType(Class<R>) - Method in interface org.corfudb.runtime.object.IObjectBuilder
-
Set the type of this object, using a class.
- setType(Class<R>) - Method in class org.corfudb.runtime.view.ObjectBuilder
-
- setTypeToken(TypeToken<R>) - Method in interface org.corfudb.runtime.object.IObjectBuilder
-
Set the type of this object, using a type token.
- setTypeToken(TypeToken<R>) - Method in class org.corfudb.runtime.view.ObjectBuilder
-
- setUndoRecord(Object) - Method in class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
Set the undo record for this entry.
- setUpcallResult(Object) - Method in class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
Set the upcall result for this entry.
- setWriteRetry(int) - Method in class org.corfudb.runtime.CorfuRuntime
-
- ShellMain - Class in org.corfudb.shell
-
Created by mwei on 11/18/16.
- ShellMain() - Constructor for class org.corfudb.shell.ShellMain
-
- shutdown() - Method in class org.corfudb.infrastructure.AbstractServer
-
Shutdown the server.
- SHUTDOWN - Static variable in class org.corfudb.infrastructure.BatchWriterOperation
-
- shutdown() - Method in class org.corfudb.infrastructure.log.StreamLogCompaction
-
- shutdown() - Method in class org.corfudb.infrastructure.LogUnitServer
-
Shutdown the server.
- shutdown() - Method in class org.corfudb.infrastructure.ManagementAgent
-
Shutdown the initializationTaskThread and monitoring services.
- shutdown() - Method in class org.corfudb.infrastructure.ManagementServer
-
Management Server shutdown:
Shuts down the fault detector service.
- shutdown() - Method in interface org.corfudb.infrastructure.MonitoringService
-
Clean up.
- shutdown() - Method in class org.corfudb.infrastructure.orchestrator.Orchestrator
-
Shuts down the orchestrator executor.
- shutdown() - Method in class org.corfudb.infrastructure.RemoteMonitoringService
-
- shutdown() - Method in class org.corfudb.infrastructure.SequencerServer
-
- shutdown - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
Whether or not this router is shutdown.
- shutdown() - Method in class org.corfudb.runtime.CorfuRuntime
-
Shuts down the CorfuRuntime.
- shutdown() - Method in class org.corfudb.runtime.NodeRouterPool
-
Shutdown all the routers in the pool.
- shutdown() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
- shutdown() - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
- shutdown() - Method in class org.corfudb.universe.universe.docker.DockerUniverse
-
- shutdown() - Method in class org.corfudb.universe.universe.process.ProcessUniverse
-
- shutdown() - Method in interface org.corfudb.universe.universe.Universe
-
- shutdown() - Method in class org.corfudb.universe.universe.vm.VmUniverse
-
- SHUTDOWN_TIMER - Static variable in class org.corfudb.infrastructure.ServerContext
-
- shutdownGroups() - Method in class org.corfudb.universe.universe.AbstractUniverse
-
- SimpleAtomicTransaction - Class in org.corfudb.samples
-
Consider again the code from org.corfudb.samples::HeloCorfu.java
:
Integer previous = map.get("a");
if (previous == null) {
System.out.println("This is the first time we were run!");
map.put("a", 1);
}
else {
map.put("a", ++previous);
System.out.println("This is the " + previous + " time we were run!");
}
If three program instances arrive at this code piece one after another, then the outcome would be:
"This is the first time we were run!"
"...
- SimpleAtomicTransaction() - Constructor for class org.corfudb.samples.SimpleAtomicTransaction
-
- SimpleUseBaseCorfuCollections - Class in org.corfudb.samples
-
The Corfu Runtime includes a collection of commodity Corfu objects.
- SimpleUseBaseCorfuCollections() - Constructor for class org.corfudb.samples.SimpleUseBaseCorfuCollections
-
- SimpleUseCustomBaseCorfuObject - Class in org.corfudb.samples
-
- SimpleUseCustomBaseCorfuObject() - Constructor for class org.corfudb.samples.SimpleUseCustomBaseCorfuObject
-
- simpleUUIDHash(UUID, long) - Static method in class org.corfudb.util.Utils
-
simple UUID hashing, which is *not* hashing, and is effectively
customized to the task of deterministically allocating new UUIDs
based on a given UUID (which is necessary in the assignment of stream
IDs in ICOrfuDBObjects that contain others, since syncing the log in
multiple clients needs allocators to produce the same streamID/object
every time).
- SingletonResource<T> - Class in org.corfudb.util.concurrent
-
Utility class which implements a singleton resource pattern.
- size() - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Graph size
- size() - Method in class org.corfudb.infrastructure.SequencerServerCache
-
The cache size
- size() - Method in class org.corfudb.protocols.wireprotocol.ClusterState
-
- size() - Method in class org.corfudb.runtime.collections.CorfuTable
- size() - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Returns the number of key-value mappings in this map.
- size() - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- size() - Method in class org.corfudb.universe.group.cluster.CorfuClusterParams
-
- size() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- Sleep - Enum in org.corfudb.util
-
Utils for sleeping with or without interruptions using timeunits, much like
TimeUnit
's sleep functionality.
- SleepOperation - Class in org.corfudb.generator.operations
-
Created by maithem on 7/14/17.
- SleepOperation(State) - Constructor for class org.corfudb.generator.operations.SleepOperation
-
- sleepRecoverably(long) - Method in enum org.corfudb.util.Sleep
-
Sleep, throwing an
InterruptedException
if the sleep is interrupted, re-setting the interrupted flag.
- sleepUninterruptibly(Duration) - Static method in enum org.corfudb.util.Sleep
-
Sleep, without recovery logic in case the sleep is interrupted.
- sleepUninterruptibly(long) - Method in enum org.corfudb.util.Sleep
-
Sleep, without recovery logic in case the sleep is interrupted.
- SMALL_INTERVAL - Static variable in class org.corfudb.infrastructure.ServerContext
-
various duration constants.
- SMREntry - Class in org.corfudb.protocols.logprotocol
-
Deprecated.
- SMREntry(String, Object[], ISerializer) - Constructor for class org.corfudb.protocols.logprotocol.SMREntry
-
Deprecated.
SMREntry constructor.
- SMRMap<K,V> - Class in org.corfudb.runtime.collections
-
Deprecated.
- SMRMap() - Constructor for class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
- SnapshotTransactionalContext - Class in org.corfudb.runtime.object.transactions
-
A snapshot transactional context.
- SnapshotTransactionalContext(Transaction) - Constructor for class org.corfudb.runtime.object.transactions.SnapshotTransactionalContext
-
- SnapshotTxOperation - Class in org.corfudb.generator.operations
-
Created by box on 7/15/17.
- SnapshotTxOperation(State) - Constructor for class org.corfudb.generator.operations.SnapshotTxOperation
-
- Spec<T,R> - Interface in org.corfudb.universe.scenario.spec
-
- Spec.AbstractSpec<T,R> - Class in org.corfudb.universe.scenario.spec
-
- spliterator() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Get a spliterator for this stream view
- spliterator() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- spliteratorUpTo(long) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Get a spliterator for this stream view, limiting the return
values to a specified global address.
- SslContextConstructor - Class in org.corfudb.security.tls
-
- SslContextConstructor() - Constructor for class org.corfudb.security.tls.SslContextConstructor
-
- StaleTokenException - Exception in org.corfudb.runtime.exceptions
-
The exception is thrown internally by the runtime
if the following race happens:
a token is obtained from sequencer at epoch x,
then reconfiguration happens and a new layout with epoch x+k is installed,
finally the action with epoch x resumes.
- StaleTokenException(long) - Constructor for exception org.corfudb.runtime.exceptions.StaleTokenException
-
- start(Duration) - Method in interface org.corfudb.infrastructure.MonitoringService
-
Starts the long running service.
- start(Duration) - Method in class org.corfudb.infrastructure.RemoteMonitoringService
-
Executes task to run failure and healing detection every poll interval.
- start() - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Starts routing requests.
- start() - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
- start() - Method in class org.corfudb.runtime.ViewsGarbageCollector
-
- start() - Method in interface org.corfudb.universe.node.server.CorfuServer
-
- start() - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
- start() - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- start(String) - Method in class org.corfudb.universe.util.DockerManager
-
Start a docker container
- startAndListen(EventLoopGroup, EventLoopGroup, CorfuServer.BootstrapConfigurer, ServerContext, NettyServerRouter, String, int) - Static method in class org.corfudb.infrastructure.CorfuServer
-
Start the Corfu server and bind it to the given port
using the provided
channelType
.
- startCheckpoint(Token, long) - Method in class org.corfudb.runtime.CheckpointWriter
-
Append a checkpoint START record to this object's stream.
- STARTING_ADDRESS_KEY - Static variable in class org.corfudb.infrastructure.log.StreamLogDataStore
-
- STARTING_ADDRESS_PREFIX - Static variable in class org.corfudb.infrastructure.log.StreamLogDataStore
-
- STARTING_ADDRESS_RECORD - Static variable in class org.corfudb.infrastructure.log.StreamLogDataStore
-
- startOptimisticTx() - Method in class org.corfudb.generator.State
-
- startServer(Map<String, Object>, boolean) - Static method in class org.corfudb.infrastructure.CorfuServer
-
Creates all the components of the Corfu Server.
- startSnapshotTx() - Method in class org.corfudb.generator.State
-
- startSnapshotTx(Token) - Method in class org.corfudb.generator.State
-
- startTime - Variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
The start time of the context.
- startWriteAfterWriteTx() - Method in class org.corfudb.generator.State
-
- state - Variable in class org.corfudb.generator.operations.Operation
-
- State - Class in org.corfudb.generator
-
This object keeps state information of the different data distributions and runtime client.
- State(int, int, CorfuRuntime) - Constructor for class org.corfudb.generator.State
-
- StateSource - Enum in org.corfudb.annotations
-
Where the state of the object should come from.
- StateTransfer - Class in org.corfudb.infrastructure.orchestrator.actions
-
State transfer utility.
- StaticMappingObject - Class in org.corfudb.annotations
-
Created by mwei on 3/29/16.
- StaticMappingObject() - Constructor for class org.corfudb.annotations.StaticMappingObject
-
- stop() - Method in interface org.corfudb.runtime.clients.IClientRouter
-
Stops routing requests.
- stop(boolean) - Method in interface org.corfudb.runtime.clients.IClientRouter
-
- stop() - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
Stops routing requests.
- stop(boolean) - Method in class org.corfudb.runtime.clients.NettyClientRouter
-
- stop() - Method in class org.corfudb.runtime.CorfuRuntime
-
Stop all routers associated with this runtime & disconnect them.
- stop(boolean) - Method in class org.corfudb.runtime.CorfuRuntime
-
Stop all routers associated with this Corfu Runtime.
- stop() - Method in class org.corfudb.runtime.ViewsGarbageCollector
-
- stop(Duration) - Method in class org.corfudb.universe.group.cluster.AbstractCorfuCluster
-
Stop the cluster
- stop(Duration) - Method in interface org.corfudb.universe.group.Group
-
Stop the
Group
by stopping all individual
Node
-s of the group.
- stop(Duration) - Method in class org.corfudb.universe.node.client.LocalCorfuClient
-
Shutdown corfu runtime
- stop(Duration) - Method in interface org.corfudb.universe.node.Node
-
Stops a
Node
gracefully within the timeout provided to this method.
- stop(Duration) - Method in class org.corfudb.universe.node.server.docker.DockerCorfuServer
-
This method attempts to gracefully stop the Corfu server.
- stop(Duration) - Method in class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- stop(String, Duration) - Method in class org.corfudb.universe.util.DockerManager
-
This method attempts to gracefully stop a container and kill it after timeout.
- stopConditionalContext(Timer.Context) - Static method in class org.corfudb.util.MetricsUtils
-
- stopTx() - Method in class org.corfudb.generator.State
-
- stream() - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- stream() - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- stream() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- stream() - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Get a Java stream from this stream view.
- stream() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- StreamAddressRange - Class in org.corfudb.protocols.wireprotocol
-
This class represents a range of addresses for a stream.
- StreamAddressRange() - Constructor for class org.corfudb.protocols.wireprotocol.StreamAddressRange
-
- StreamAddressSpace - Class in org.corfudb.runtime.view.stream
-
This class represents the space of all addresses belonging to a stream.
- StreamAddressSpace(long, Roaring64NavigableMap) - Constructor for class org.corfudb.runtime.view.stream.StreamAddressSpace
-
- StreamLog - Interface in org.corfudb.infrastructure.log
-
An interface definition that specifies an api to interact with a StreamLog.
- StreamLogCompaction - Class in org.corfudb.infrastructure.log
-
Scheduled log compaction manager.
- StreamLogCompaction(StreamLog, long, long, TimeUnit, Duration) - Constructor for class org.corfudb.infrastructure.log.StreamLogCompaction
-
- StreamLogDataStore - Class in org.corfudb.infrastructure.log
-
Data access layer for StreamLog.
- StreamLogDataStore() - Constructor for class org.corfudb.infrastructure.log.StreamLogDataStore
-
- StreamLogFiles - Class in org.corfudb.infrastructure.log
-
This class implements the StreamLog by persisting the stream log as records in multiple files.
- StreamLogFiles(ServerContext, boolean) - Constructor for class org.corfudb.infrastructure.log.StreamLogFiles
-
Returns a file-based stream log object.
- StreamLogFiles.Checksum - Class in org.corfudb.infrastructure.log
-
- StreamLogWithRankedAddressSpace - Interface in org.corfudb.infrastructure.log
-
Stream log that is able to compare the data on the same log address using the rank and type.
- StreamOptions - Class in org.corfudb.runtime.view
-
Created by maithem on 6/20/17.
- StreamOptions(boolean) - Constructor for class org.corfudb.runtime.view.StreamOptions
-
- StreamOptions.StreamOptionsBuilder - Class in org.corfudb.runtime.view
-
- StreamOptionsBuilder() - Constructor for class org.corfudb.runtime.view.StreamOptions.StreamOptionsBuilder
-
- Streams - Class in org.corfudb.generator.distributions
-
This class implements a distribution over the possible streams that
can be created/modified.
- Streams(int) - Constructor for class org.corfudb.generator.distributions.Streams
-
- STREAMS - Static variable in class org.corfudb.protocols.wireprotocol.StreamsAddressRequest
-
- STREAMS_TAILS - Static variable in class org.corfudb.protocols.wireprotocol.TailsRequest
-
- StreamsAddressRequest - Class in org.corfudb.protocols.wireprotocol
-
Represents the request sent to the sequencer to retrieve one or several streams address map.
- StreamsAddressRequest(List<StreamAddressRange>) - Constructor for class org.corfudb.protocols.wireprotocol.StreamsAddressRequest
-
- StreamsAddressRequest(Byte) - Constructor for class org.corfudb.protocols.wireprotocol.StreamsAddressRequest
-
- StreamsAddressRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.StreamsAddressRequest
-
Deserialization Constructor from Bytebuf to StreamsAddressRequest.
- StreamsAddressResponse - Class in org.corfudb.protocols.wireprotocol
-
Represents the response sent by the sequencer when streams address maps are requested
- StreamsAddressResponse(long, Map<UUID, StreamAddressSpace>) - Constructor for class org.corfudb.protocols.wireprotocol.StreamsAddressResponse
-
- StreamsAddressResponse(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.StreamsAddressResponse
-
Deserialization Constructor from Bytebuf to StreamsAddressResponse.
- StreamSpliterator - Class in org.corfudb.runtime.view.stream
-
A spliterator for streams, which supports limiting the
spliterator's scope to a maximum global address.
- StreamSpliterator(IStreamView) - Constructor for class org.corfudb.runtime.view.stream.StreamSpliterator
-
Construct a stream spliterator with the given view and no limit.
- StreamSpliterator(IStreamView, long) - Constructor for class org.corfudb.runtime.view.stream.StreamSpliterator
-
Construct a stream spliterator with the given view and limit
- StreamsView - Class in org.corfudb.runtime.view
-
Created by mwei on 12/11/15.
- StreamsView(CorfuRuntime) - Constructor for class org.corfudb.runtime.view.StreamsView
-
- streamUpTo(long) - Method in interface org.corfudb.runtime.object.ISMRStream
-
Deprecated.
- streamUpTo(long) - Method in class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- streamUpTo(long) - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- streamUpTo(long) - Method in interface org.corfudb.runtime.view.stream.IStreamView
-
Get a Java stream from this stream view, limiting
reads to a specified global address.
- StreamViewSMRAdapter - Class in org.corfudb.runtime.object
-
Deprecated.
- StreamViewSMRAdapter(CorfuRuntime, IStreamView) - Constructor for class org.corfudb.runtime.object.StreamViewSMRAdapter
-
Deprecated.
- Stress - Interface in org.corfudb.universe.node.stress
-
- stressCPULoad() - Method in interface org.corfudb.universe.node.stress.Stress
-
To stress CPU usage on a node.
- stressCPULoad() - Method in class org.corfudb.universe.node.stress.vm.VmStress
-
- stressDiskLoad() - Method in interface org.corfudb.universe.node.stress.Stress
-
To stress disk usage on a node.
- stressDiskLoad() - Method in class org.corfudb.universe.node.stress.vm.VmStress
-
- stressIOLoad() - Method in interface org.corfudb.universe.node.stress.Stress
-
To stress IO usage on a node.
- stressIOLoad() - Method in class org.corfudb.universe.node.stress.vm.VmStress
-
- stressMemoryLoad() - Method in interface org.corfudb.universe.node.stress.Stress
-
To stress memory (RAM) usage on a node.
- stressMemoryLoad() - Method in class org.corfudb.universe.node.stress.vm.VmStress
-
- StringIndexer - Class in org.corfudb.generator
-
- StringIndexer() - Constructor for class org.corfudb.generator.StringIndexer
-
- SUN_JAVA_COMMAND - Static variable in class org.corfudb.util.Utils
-
Sun property pointing the main class and its arguments.
- sync(boolean) - Method in class org.corfudb.infrastructure.log.InMemoryStreamLog
-
- sync(boolean) - Method in interface org.corfudb.infrastructure.log.StreamLog
-
Sync the stream log file to secondary storage.
- sync(boolean) - Method in class org.corfudb.infrastructure.log.StreamLogFiles
-
- sync() - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Update the proxy to the latest committed version.
- sync() - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Update the proxy to the latest committed version.
- syncDirectory(String) - Static method in class org.corfudb.infrastructure.utils.Persistence
-
This method fsyncs a directory.
- syncObjectUnsafe(long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Bring the object to the requested version, rolling back or syncing
the object from the log if necessary to reach the requested version.
- syncStreamUnsafe(ISMRStream, long) - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Sync this stream by playing updates forward in the stream until
the given timestamp.
- syncWithRetryUnsafe(VersionLockedObject, Token, ICorfuSMRProxyInternal, Consumer<VersionLockedObject>) - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
- SYSTEM_SERIALIZERS_COUNT - Static variable in class org.corfudb.util.serializer.Serializers
-
- systemDownHandler() - Method in interface org.corfudb.universe.node.client.CorfuClient
-
A handler which is invoked at any point when the Corfu client
attempts to make an RPC request to the Corfu cluster but is
unable to complete.
- SystemUnavailableError - Error in org.corfudb.runtime.exceptions.unrecoverable
-
Created by rmichoud on 10/31/17.
- SystemUnavailableError(String) - Constructor for error org.corfudb.runtime.exceptions.unrecoverable.SystemUnavailableError
-
- tags - Variable in class org.corfudb.util.GitRepositoryState
-
- TAIL_SEGMENT_KEY - Static variable in class org.corfudb.infrastructure.log.StreamLogDataStore
-
- TAIL_SEGMENT_RECORD - Static variable in class org.corfudb.infrastructure.log.StreamLogDataStore
-
- TailsRequest - Class in org.corfudb.protocols.wireprotocol
-
A tail request can be specific to the following types:
- Global log tail.
- TailsRequest(List<UUID>) - Constructor for class org.corfudb.protocols.wireprotocol.TailsRequest
-
Constructor for TailsRequest.
- TailsRequest(byte) - Constructor for class org.corfudb.protocols.wireprotocol.TailsRequest
-
- TailsRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.TailsRequest
-
Deserialization Constructor from Bytebuf to TailsRequest.
- TailsResponse - Class in org.corfudb.protocols.wireprotocol
-
A container that contains information about the log's stream tails
map and max global address written (i.e.
- TailsResponse(long) - Constructor for class org.corfudb.protocols.wireprotocol.TailsResponse
-
- TailsResponse(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.TailsResponse
-
- ThreadSafeStreamView - Class in org.corfudb.runtime.view.stream
-
A thread-safe implementation of IStreamView.
- ThreadSafeStreamView(CorfuRuntime, UUID, StreamOptions) - Constructor for class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- ThreadSafeStreamView(CorfuRuntime, UUID) - Constructor for class org.corfudb.runtime.view.stream.ThreadSafeStreamView
-
- timeout - Variable in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
- timeoutConnect - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
New connection timeout (milliseconds).
- timeoutResponse - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
Sync call response timeout (milliseconds).
- timeoutRetry - Variable in class org.corfudb.runtime.clients.NettyClientRouter
-
Retry interval after timeout (milliseconds).
- TK_MULTI_STREAM - Static variable in class org.corfudb.protocols.wireprotocol.TokenRequest
-
- TK_QUERY - Static variable in class org.corfudb.protocols.wireprotocol.TokenRequest
-
- TK_RAW - Static variable in class org.corfudb.protocols.wireprotocol.TokenRequest
-
- TK_TX - Static variable in class org.corfudb.protocols.wireprotocol.TokenRequest
-
- TlsUtils - Class in org.corfudb.security.tls
-
Utilities for common options parsing and session configuration for
encrypted & authenticated TLS sessions.
- toArray() - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- toArray(T[]) - Method in class org.corfudb.util.ImmuableListSetWrapper
-
- toClusterGraph(ClusterState, String) - Static method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Transform a cluster state to the cluster graph.
- toJson() - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
- toJson() - Method in class org.corfudb.protocols.wireprotocol.failuredetector.FailureDetectorMetrics
-
- toJson(T) - Static method in class org.corfudb.util.JsonUtils
-
- Token - Class in org.corfudb.protocols.wireprotocol
-
Token returned by the sequencer is a combination of the
sequence number and the epoch at which it was acquired.
- Token() - Constructor for class org.corfudb.protocols.wireprotocol.Token
-
- tokenRequest(CorfuPayloadMsg<TokenRequest>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.SequencerServer
-
Service an incoming token request.
- TokenRequest - Class in org.corfudb.protocols.wireprotocol
-
A token request is at the heart of the Corfu log protocol.
- TokenRequest(Long, List<UUID>, TxResolutionInfo) - Constructor for class org.corfudb.protocols.wireprotocol.TokenRequest
-
Constructor for generating TokenRequest.
- TokenRequest(Long, List<UUID>) - Constructor for class org.corfudb.protocols.wireprotocol.TokenRequest
-
Constructor for generating TokenRequest.
- TokenRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.TokenRequest
-
Deserialization Constructor from Bytebuf to TokenRequest.
- TokenResponse - Class in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/8/16.
- TokenResponse(Token, Map<UUID, Long>) - Constructor for class org.corfudb.protocols.wireprotocol.TokenResponse
-
Constructor for TokenResponse.
- TokenResponse(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.TokenResponse
-
Deserialization Constructor from a Bytebuf to TokenResponse.
- TokenType - Enum in org.corfudb.protocols.wireprotocol
-
An enum for distinguishing different response from the sequencer.
- toReadableId(UUID) - Static method in class org.corfudb.util.Utils
-
Generates a human readable UUID string (4 hex chars) using time_mid.
- toString() - Method in class org.corfudb.infrastructure.SequencerServerCache.ConflictTxStream
-
- toString() - Method in class org.corfudb.protocols.wireprotocol.LogData
-
- toString() - Method in class org.corfudb.protocols.wireprotocol.TxResolutionInfo
-
- toString() - Method in interface org.corfudb.runtime.collections.ISMRObject
-
Deprecated.
- toString() - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
- toString() - Method in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
- toString() - Method in class org.corfudb.runtime.object.transactions.WriteSetSMRStream
-
Deprecated.
- toString() - Method in class org.corfudb.runtime.object.VersionLockedObject
-
Generate the summary string for this version locked object.
- toString() - Method in class org.corfudb.runtime.view.ObjectsView.ObjectID
-
- toString() - Method in class org.corfudb.runtime.view.stream.AbstractContextStreamView
-
- toString() - Method in class org.corfudb.runtime.view.workflows.AddNode
-
- toString() - Method in class org.corfudb.runtime.view.workflows.ForceRemoveNode
-
- toString() - Method in class org.corfudb.runtime.view.workflows.HealNode
-
- toString() - Method in class org.corfudb.runtime.view.workflows.RemoveNode
-
- toString() - Method in class org.corfudb.runtime.view.workflows.RestoreRedundancyMergeSegments
-
- toString() - Method in enum org.corfudb.util.CorfuComponent
-
- toString() - Method in class org.corfudb.util.NodeLocator
-
- toSymmetric() - Method in class org.corfudb.infrastructure.management.failuredetector.ClusterGraph
-
Convert a cluster graph which could have asymmetric failures to a graph with symmetric failures between nodes.
- transaction - Variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
The builder used to create this transaction.
- Transaction - Class in org.corfudb.runtime.object.transactions
-
Represents a transaction.
- Transaction() - Constructor for class org.corfudb.runtime.object.transactions.Transaction
-
- TRANSACTION_STREAM_ID - Static variable in class org.corfudb.runtime.view.ObjectsView
-
The Transaction stream is used to log/write successful transactions from different clients.
- TransactionAbortedException - Exception in org.corfudb.runtime.exceptions
-
Created by mwei on 1/11/16.
- TransactionAbortedException(TxResolutionInfo, byte[], UUID, Long, AbortCause, AbstractTransactionalContext) - Constructor for exception org.corfudb.runtime.exceptions.TransactionAbortedException
-
Constructor.
- TransactionAbortedException(TxResolutionInfo, AbortCause, Throwable, AbstractTransactionalContext) - Constructor for exception org.corfudb.runtime.exceptions.TransactionAbortedException
-
- TransactionAbortedException(TxResolutionInfo, byte[], UUID, Long, AbortCause, Throwable, AbstractTransactionalContext) - Constructor for exception org.corfudb.runtime.exceptions.TransactionAbortedException
-
- TransactionalContext - Class in org.corfudb.runtime.object.transactions
-
A class which allows access to transactional contexts, which manage
transactions.
- TransactionalContext() - Constructor for class org.corfudb.runtime.object.transactions.TransactionalContext
-
- TransactionalMethod - Annotation Type in org.corfudb.annotations
-
Marks that this method should be execute transactionally.
- transactionID - Variable in class org.corfudb.runtime.object.transactions.AbstractTransactionalContext
-
The ID of the transaction.
- TransactionType - Enum in org.corfudb.runtime.object.transactions
-
Created by mwei on 11/21/16.
- transfer(Layout, Set<String>, CorfuRuntime, Layout.LayoutSegment) - Static method in class org.corfudb.infrastructure.orchestrator.actions.StateTransfer
-
Fetch and propagate the trimMark to the new/healing nodes.
- trim(Long) - Method in class org.corfudb.runtime.view.stream.StreamAddressSpace
-
Trim all addresses lower or equal to trimMark and set new trim mark.
- trimCache(CorfuPayloadMsg<Long>, ChannelHandlerContext, IServerRouter) - Method in class org.corfudb.infrastructure.SequencerServer
-
- trimCache(Long) - Method in class org.corfudb.runtime.clients.SequencerClient
-
- trimCache(long) - Method in class org.corfudb.runtime.view.SequencerView
-
- TrimmedException - Exception in org.corfudb.runtime.exceptions
-
This exception is thrown when a client tries to read an address
that has been trimmed.
- TrimmedException() - Constructor for exception org.corfudb.runtime.exceptions.TrimmedException
-
- TrimmedException(String) - Constructor for exception org.corfudb.runtime.exceptions.TrimmedException
-
- TrimmedUpcallException - Exception in org.corfudb.runtime.exceptions
-
This exception is thrown when a client attempts to resolve
an upcall, but the address is trimmed before the upcall
result can be resolved.
- TrimmedUpcallException(long) - Constructor for exception org.corfudb.runtime.exceptions.TrimmedUpcallException
-
- TrimRequest - Class in org.corfudb.protocols.wireprotocol
-
Created by mwei on 8/8/16.
- TrimRequest(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.TrimRequest
-
Deserialization Constructor from Bytebuf to TrimRequest.
- tryAdvance(Consumer<? super ILogData>) - Method in class org.corfudb.runtime.view.stream.StreamSpliterator
- tryCommitAllProxies() - Method in class org.corfudb.runtime.object.transactions.OptimisticTransactionalContext
-
Try to commit the optimistic updates to each proxy.
- TX_ABORTED - Static variable in class org.corfudb.generator.Correctness
-
- TX_END - Static variable in class org.corfudb.generator.Correctness
-
- TX_START - Static variable in class org.corfudb.generator.Correctness
-
- TXAbort() - Method in class org.corfudb.runtime.view.ObjectsView
-
Aborts a transaction on the current thread.
- TXActive() - Method in class org.corfudb.runtime.view.ObjectsView
-
Query whether a transaction is currently running.
- TXBegin() - Method in class org.corfudb.runtime.view.ObjectsView
-
Begins a transaction on the current thread.
- TXBegin() - Method in class org.corfudb.samples.BaseCorfuAppUtils
-
Utility method to start a (default type) TX
Can be overriden by classes that require non-default transaction type.
- TXBegin() - Method in class org.corfudb.samples.WriteWriteTXs
-
This overrides TXBegin in order to set the transaction type to WRITE_AFTER_WRITE
- TXBuild() - Method in class org.corfudb.runtime.view.ObjectsView
-
Builds a new transaction using the transaction
builder.
- TXEnd() - Method in class org.corfudb.runtime.view.ObjectsView
-
End a transaction on the current thread.
- TXEnd() - Method in class org.corfudb.samples.BaseCorfuAppUtils
-
Utility method to end a TX
- TXExecute(Supplier<R>) - Method in class org.corfudb.runtime.object.CorfuCompileProxy
-
Run in a transactional context.
- TXExecute(Supplier<R>) - Method in interface org.corfudb.runtime.object.ICorfuSMRProxy
-
Run in a transactional context.
- TxResolutionInfo - Class in org.corfudb.protocols.wireprotocol
-
Created by dmalkhi on 12/26/16.
- TxResolutionInfo(UUID, Token) - Constructor for class org.corfudb.protocols.wireprotocol.TxResolutionInfo
-
Constructor for TxResolutionInfo.
- TxResolutionInfo(UUID, Token, Map<UUID, Set<byte[]>>, Map<UUID, Set<byte[]>>) - Constructor for class org.corfudb.protocols.wireprotocol.TxResolutionInfo
-
Constructor for TxResolutionInfo.
- TxResolutionInfo(ByteBuf) - Constructor for class org.corfudb.protocols.wireprotocol.TxResolutionInfo
-
fast, specialized deserialization constructor, from a ByteBuf to this object
- type - Variable in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointDictKey
-
- type - Variable in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointEntryType
-
- type - Variable in enum org.corfudb.protocols.logprotocol.LogEntry.LogEntryType
-
- type - Variable in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
- type - Variable in enum org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorRequestType
-
- type - Variable in enum org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorResponseType
-
- typeMap - Static variable in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointDictKey
-
- typeMap - Static variable in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointEntryType
-
- typeMap - Static variable in enum org.corfudb.protocols.wireprotocol.DataType
-
- typeMap - Static variable in enum org.corfudb.protocols.wireprotocol.IMetadata.LogUnitMetadataType
-
- validateEpoch(CorfuMsg, ChannelHandlerContext) - Method in class org.corfudb.infrastructure.NettyServerRouter
-
Validate the epoch of a CorfuMsg, and send a WRONG_EPOCH response if
the server is in the wrong epoch.
- validateGlobalPointerPosition(long) - Method in class org.corfudb.runtime.view.stream.AbstractStreamContext
-
Validate that Global Pointer position does not fall in the GC trim range.
- validateSegmentSeal(Layout.LayoutSegment, Map<String, CompletableFuture<Boolean>>) - Method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
Seals the layout segment.
- ValueAdoptedException - Exception in org.corfudb.runtime.exceptions
-
Returned during recovery write of the quorum replication, when a new value should be adopted
Created by kspirov on 3/21/17.
- ValueAdoptedException() - Constructor for exception org.corfudb.runtime.exceptions.ValueAdoptedException
-
- valueOf(String) - Static method in enum org.corfudb.annotations.ConstructorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.annotations.ObjectType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.annotations.StateSource
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.comm.ChannelImplementation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.infrastructure.AbstractServer.ServerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.infrastructure.BatchWriterOperation.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.infrastructure.management.ClusterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.infrastructure.orchestrator.ActionStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.infrastructure.RemoteMonitoringService.DetectorTask
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointDictKey
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointEntryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.logprotocol.LogEntry.LogEntryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.ClientHandshakeHandler.ClientHandshakeEvent
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.FailureDetectorMetrics.FailureDetectorAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity.ConnectionStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity.NodeConnectivityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.IMetadata.LogUnitMetadataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorRequestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorResponseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.SequencerMetrics.SequencerStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.protocols.wireprotocol.TokenType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.collections.ISMRMap.UndoNullable
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.exceptions.AbortCause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.exceptions.OverwriteCause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.object.transactions.TransactionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.CacheOption
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.ClusterStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.ClusterStatusReliability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.ConnectivityStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.NodeStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.ObjectOpenOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.stream.AbstractQueuedStreamView.BackpointerOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.runtime.view.stream.IStreamView.SearchDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.universe.node.Node.NodeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.universe.node.server.CorfuServer.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.universe.node.server.CorfuServer.Persistence
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.universe.universe.Universe.UniverseMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.util.CorfuComponent
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.util.NodeLocator.Protocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.corfudb.util.Sleep
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.corfudb.annotations.ConstructorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.annotations.ObjectType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.annotations.StateSource
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.comm.ChannelImplementation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.infrastructure.AbstractServer.ServerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.infrastructure.BatchWriterOperation.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.infrastructure.management.ClusterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.infrastructure.orchestrator.ActionStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.infrastructure.RemoteMonitoringService.DetectorTask
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointDictKey
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.logprotocol.CheckpointEntry.CheckpointEntryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.logprotocol.LogEntry.LogEntryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.ClientHandshakeHandler.ClientHandshakeEvent
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.CorfuMsgType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.DataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.FailureDetectorMetrics.FailureDetectorAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity.ConnectionStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.failuredetector.NodeConnectivity.NodeConnectivityType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.IMetadata.LogUnitMetadataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorRequestType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.orchestrator.OrchestratorResponseType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.SequencerMetrics.SequencerStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.protocols.wireprotocol.TokenType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.corfudb.runtime.collections.CorfuTable
- values() - Method in class org.corfudb.runtime.collections.FGMap
-
Deprecated.
Returns a
Collection
view of the values contained in this map.
- values() - Static method in enum org.corfudb.runtime.collections.ISMRMap.UndoNullable
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.corfudb.runtime.collections.ISMRMap
-
Deprecated.
- values() - Method in class org.corfudb.runtime.collections.SMRMap
-
Deprecated.
Returns a
Collection
view of the values contained in this map.
- values() - Static method in enum org.corfudb.runtime.exceptions.AbortCause
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.exceptions.OverwriteCause
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.object.transactions.TransactionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.CacheOption
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.ClusterStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.ClusterStatusReliability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.ConnectivityStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.ClusterStatusReport.NodeStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.Layout.ReplicationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.ObjectOpenOptions
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.stream.AbstractQueuedStreamView.BackpointerOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.runtime.view.stream.IStreamView.SearchDirection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.universe.node.Node.NodeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.universe.node.server.CorfuServer.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.universe.node.server.CorfuServer.Persistence
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.universe.universe.Universe.UniverseMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.util.CorfuComponent
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.util.NodeLocator.Protocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.corfudb.util.Sleep
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verifyRequest(Layout) - Method in class org.corfudb.runtime.view.workflows.AddNode
-
- verifyRequest(Layout) - Method in class org.corfudb.runtime.view.workflows.HealNode
-
- verifyRequest(Layout) - Method in class org.corfudb.runtime.view.workflows.RemoveNode
-
- verifyRequest(Layout) - Method in class org.corfudb.runtime.view.workflows.RestoreRedundancyMergeSegments
-
Verify request has been completed if the layout contains only one segment.
- verifyRequest(Layout) - Method in class org.corfudb.runtime.view.workflows.WorkflowRequest
-
Infer the completion of the request by inspecting the layout
- VERSION - Static variable in class org.corfudb.infrastructure.log.StreamLogFiles
-
- Version - Class in org.corfudb.util
-
Created by mwei on 1/29/16.
- Version() - Constructor for class org.corfudb.util.Version
-
- VersionInfo - Class in org.corfudb.protocols.wireprotocol
-
Created by mwei on 7/27/16.
- VersionInfo(Map<String, Object>, String) - Constructor for class org.corfudb.protocols.wireprotocol.VersionInfo
-
Create a new version info, using the current options map and node id.
- VersionLockedObject<T> - Class in org.corfudb.runtime.object
-
The VersionLockedObject maintains a versioned object which is backed by an ISMRStream, and is
optionally backed by an additional optimistic update stream.
- VersionLockedObject(Supplier<T>, StreamViewSMRAdapter, Map<String, ICorfuSMRUpcallTarget<T>>, Map<String, IUndoRecordFunction<T>>, Map<String, IUndoFunction<T>>, Set<String>) - Constructor for class org.corfudb.runtime.object.VersionLockedObject
-
The VersionLockedObject maintains a versioned object which is backed by an ISMRStream,
and is optionally backed by an additional optimistic update stream.
- ViewsGarbageCollector - Class in org.corfudb.runtime
-
A CorfuRuntime garbage collector.
- ViewsGarbageCollector(CorfuRuntime) - Constructor for class org.corfudb.runtime.ViewsGarbageCollector
-
- VmCorfuCluster - Class in org.corfudb.universe.group.cluster.vm
-
- VmCorfuCluster(CorfuClusterParams, VmUniverseParams, ImmutableMap<String, VirtualMachine>) - Constructor for class org.corfudb.universe.group.cluster.vm.VmCorfuCluster
-
- VmCorfuServer - Class in org.corfudb.universe.node.server.vm
-
Implements a
CorfuServer
instance that is running on VM.
- VmCorfuServer(VmCorfuServerParams, VirtualMachine, VmUniverseParams, VmStress) - Constructor for class org.corfudb.universe.node.server.vm.VmCorfuServer
-
- VmCorfuServerParams - Class in org.corfudb.universe.node.server.vm
-
- VmCorfuServerParams(String, int, CorfuServer.Mode, CorfuServer.Persistence, Level, String, Duration) - Constructor for class org.corfudb.universe.node.server.vm.VmCorfuServerParams
-
- VmStress - Class in org.corfudb.universe.node.stress.vm
-
- VmStress() - Constructor for class org.corfudb.universe.node.stress.vm.VmStress
-
- VmUniverse - Class in org.corfudb.universe.universe.vm
-
Represents VM implementation of a
Universe
.
- VmUniverse(VmUniverseParams, ApplianceManager) - Constructor for class org.corfudb.universe.universe.vm.VmUniverse
-
- VmUniverseFixture() - Constructor for class org.corfudb.universe.scenario.fixture.Fixtures.VmUniverseFixture
-
- VmUniverseParams - Class in org.corfudb.universe.universe.vm
-
Represents the parameters for constructing a VM
Universe
.
- VmUniverseParams(String, String, String, String, String, String, String, ConcurrentMap<String, String>, String) - Constructor for class org.corfudb.universe.universe.vm.VmUniverseParams
-