A B C D E F G H I J K L M N O P Q R S T U V W X Y Z
All Classes All Packages
All Classes All Packages
A
- A_TO_B - org.onosproject.ui.model.topo.UiLinkId.Direction
- abort() - Method in interface org.onosproject.store.service.TransactionContext
-
Aborts any changes made in this transaction context and discarding all locally cached updates.
- AbstractAccumulator<T> - Class in org.onlab.util
-
Base implementation of an item accumulator.
- AbstractAccumulator(Timer, int, int, int) - Constructor for class org.onlab.util.AbstractAccumulator
-
Creates an item accumulator capable of triggering on the specified thresholds.
- AbstractAnnotated - Class in org.onosproject.net
-
Base abstraction of an annotated entity.
- AbstractAnnotated() - Constructor for class org.onosproject.net.AbstractAnnotated
- AbstractAnnotated(Annotations...) - Constructor for class org.onosproject.net.AbstractAnnotated
-
Creates a new entity, annotated with the specified annotations.
- AbstractApiDocRegistrator - Class in org.onosproject.rest
-
Self-registering REST API provider.
- AbstractApiDocRegistrator(ApiDocProvider) - Constructor for class org.onosproject.rest.AbstractApiDocRegistrator
-
Creates registrator for the specified REST API doc provider.
- AbstractBehaviour - Class in org.onosproject.net.driver
-
Base implementation of a driver behaviour.
- AbstractBehaviour() - Constructor for class org.onosproject.net.driver.AbstractBehaviour
- AbstractCellComparator - Class in org.onosproject.ui.table.cell
-
Base implementation of a
CellComparator
. - AbstractCellComparator() - Constructor for class org.onosproject.ui.table.cell.AbstractCellComparator
- AbstractCellFormatter - Class in org.onosproject.ui.table.cell
-
Base implementation of a
CellFormatter
. - AbstractCellFormatter() - Constructor for class org.onosproject.ui.table.cell.AbstractCellFormatter
- AbstractChoicesCompleter - Class in org.onosproject.cli
-
Abstraction of a completer with preset choices.
- AbstractChoicesCompleter() - Constructor for class org.onosproject.cli.AbstractChoicesCompleter
- AbstractCompleter - Class in org.onosproject.cli
-
Abstract argument completer.
- AbstractCompleter() - Constructor for class org.onosproject.cli.AbstractCompleter
- AbstractDescription - Class in org.onosproject.net
-
Base implementation of an annotated model description.
- AbstractDescription() - Constructor for class org.onosproject.net.AbstractDescription
- AbstractDescription(SparseAnnotations...) - Constructor for class org.onosproject.net.AbstractDescription
-
Creates a new entity, annotated with the specified annotations.
- AbstractDeviceProvider - Class in org.onosproject.common.net
-
Base device provider capable of engaging
DeviceDescriptionDiscovery
driver behaviour to discover device and port details. - AbstractDeviceProvider(ProviderId) - Constructor for class org.onosproject.common.net.AbstractDeviceProvider
-
Creates a provider with the supplied identifier.
- AbstractDriverLoader - Class in org.onosproject.net.driver
-
Abstract bootstrapper for loading and registering driver definitions that are dependent on the default driver definitions.
- AbstractDriverLoader(String) - Constructor for class org.onosproject.net.driver.AbstractDriverLoader
-
Creates a new loader for resource with the specified path.
- AbstractEdge<V extends Vertex> - Class in org.onlab.graph
-
Abstract graph edge implementation.
- AbstractEdge(V, V) - Constructor for class org.onlab.graph.AbstractEdge
-
Creates a new edge between the specified source and destination vertexes.
- AbstractElement - Class in org.onosproject.net
-
Base implementation of network elements, i.e.
- AbstractElement() - Constructor for class org.onosproject.net.AbstractElement
- AbstractElement(ProviderId, ElementId, Annotations...) - Constructor for class org.onosproject.net.AbstractElement
-
Creates a network element attributed to the specified provider.
- AbstractEvent<T extends java.lang.Enum,S> - Class in org.onosproject.event
-
Base event implementation.
- AbstractEvent(T, S) - Constructor for class org.onosproject.event.AbstractEvent
-
Creates an event of a given type and for the specified subject and the current time.
- AbstractEvent(T, S, long) - Constructor for class org.onosproject.event.AbstractEvent
-
Creates an event of a given type and for the specified subject and time.
- AbstractExtension - Class in org.onosproject.net.flow
-
Abstract implementation of the set/get property methods of Extension.
- AbstractExtension() - Constructor for class org.onosproject.net.flow.AbstractExtension
- AbstractGraphPathSearch<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Basis for various graph path search algorithm implementations.
- AbstractGraphPathSearch() - Constructor for class org.onlab.graph.AbstractGraphPathSearch
- AbstractGraphPathSearch.DefaultResult - Class in org.onlab.graph
-
Default path search result that uses the DefaultPath to convey paths in a graph.
- AbstractHandlerBehaviour - Class in org.onosproject.net.driver
-
Base implementation of a driver handler behaviour.
- AbstractHandlerBehaviour() - Constructor for class org.onosproject.net.driver.AbstractHandlerBehaviour
- AbstractHighlight - Class in org.onosproject.ui.topo
-
Partial implementation of the highlighting to apply to topology view elements.
- AbstractHighlight(TopoElementType, String) - Constructor for class org.onosproject.ui.topo.AbstractHighlight
-
Constructs the highlight.
- AbstractIndependentDriverLoader - Class in org.onosproject.net.driver
-
Abstract bootstrapper for loading and registering driver definitions that are independent from the default driver definitions.
- AbstractIndependentDriverLoader(String) - Constructor for class org.onosproject.net.driver.AbstractIndependentDriverLoader
-
Creates a new loader for resource with the specified path.
- AbstractInjectionResource - Class in org.onosproject.rest
-
Resource for serving semi-static resources.
- AbstractInjectionResource() - Constructor for class org.onosproject.rest.AbstractInjectionResource
- AbstractInjectionResource.StreamEnumeration - Class in org.onosproject.rest
-
Auxiliary enumeration to sequence input streams.
- AbstractListenerManager<E extends Event,L extends EventListener<E>> - Class in org.onosproject.event
-
Basis for components which need to export listener mechanism.
- AbstractListenerManager() - Constructor for class org.onosproject.event.AbstractListenerManager
- AbstractListenerProviderRegistry<E extends Event,L extends EventListener<E>,P extends Provider,S extends ProviderService<P>> - Class in org.onosproject.net.provider
-
Basis for components which need to export listener mechanism.
- AbstractListenerProviderRegistry() - Constructor for class org.onosproject.net.provider.AbstractListenerProviderRegistry
- AbstractMapper<E extends java.lang.Throwable> - Class in org.onlab.rest.exceptions
-
Base exception mapper implementation.
- AbstractMapper() - Constructor for class org.onlab.rest.exceptions.AbstractMapper
- AbstractModel - Class in org.onosproject.net
-
Base implementation of a network model entity.
- AbstractModel() - Constructor for class org.onosproject.net.AbstractModel
- AbstractModel(ProviderId, Annotations...) - Constructor for class org.onosproject.net.AbstractModel
-
Creates a model entity attributed to the specified provider and optionally annotated.
- AbstractPathService - Class in org.onosproject.net.topology
-
Helper class for path service.
- AbstractPathService() - Constructor for class org.onosproject.net.topology.AbstractPathService
- AbstractProjectableModel - Class in org.onosproject.net
-
Base model entity, capable of being extended via projection mechanism.
- AbstractProjectableModel() - Constructor for class org.onosproject.net.AbstractProjectableModel
- AbstractProjectableModel(ProviderId, Annotations[]) - Constructor for class org.onosproject.net.AbstractProjectableModel
-
Creates a model entity attributed to the specified provider and optionally annotated.
- AbstractProjectableModel.AnnotationDriverData - Class in org.onosproject.net
-
Projection of the parent entity as a driver data entity.
- AbstractProvider - Class in org.onosproject.net.provider
-
Base provider implementation.
- AbstractProvider(ProviderId) - Constructor for class org.onosproject.net.provider.AbstractProvider
-
Creates a provider with the supplied identifier.
- AbstractProviderRegistry<P extends Provider,S extends ProviderService<P>> - Class in org.onosproject.net.provider
-
Base implementation of provider registry.
- AbstractProviderRegistry() - Constructor for class org.onosproject.net.provider.AbstractProviderRegistry
- AbstractProviderService<P extends Provider> - Class in org.onosproject.net.provider
-
Base implementation of a provider service, which tracks the provider to which it is issued and can be invalidated.
- AbstractProviderService(P) - Constructor for class org.onosproject.net.provider.AbstractProviderService
-
Creates a provider service on behalf of the specified provider.
- AbstractShellCommand - Class in org.onosproject.cli
-
Base abstraction of Karaf shell commands.
- AbstractShellCommand() - Constructor for class org.onosproject.cli.AbstractShellCommand
- AbstractStore<E extends Event,D extends StoreDelegate<E>> - Class in org.onosproject.store
-
Base implementation of a store.
- AbstractStore() - Constructor for class org.onosproject.store.AbstractStore
- AbstractTopoMonitor - Class in org.onosproject.ui.topo
-
Base class for the business logic of topology overlay "monitors".
- AbstractTopoMonitor() - Constructor for class org.onosproject.ui.topo.AbstractTopoMonitor
- AbstractWebApplication - Class in org.onlab.rest
-
Base web application.
- AbstractWebApplication() - Constructor for class org.onlab.rest.AbstractWebApplication
- AbstractWebResource - Class in org.onosproject.rest
-
Abstract REST resource.
- AbstractWebResource() - Constructor for class org.onosproject.rest.AbstractWebResource
- accept(U, V, W) - Method in interface org.onlab.util.TriConsumer
-
Applies the given arguments to the function.
- acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class org.onlab.util.BlockingAwareFuture
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class org.onlab.util.BlockingAwareFuture
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
- acceptPolicy(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
-
Accepts and enforces security policy to specified application.
- ACCESS - org.onosproject.net.device.DeviceInterfaceDescription.Mode
-
Access mode to a VLAN for interface.
- Accumulator<T> - Interface in org.onlab.util
-
Abstraction of an accumulator capable of collecting items and at some point in time triggers processing of all previously accumulated items.
- ACCUMULATOR_ENABLED - Static variable in interface org.onosproject.net.behaviour.Pipeliner
-
Accumulator enabled property.
- accumulatorMaxBatchMillis() - Method in interface org.onosproject.net.behaviour.PipelinerContext
-
Returns the maximum number of millis allowed since the first objective before processing is triggered.
- accumulatorMaxIdleMillis() - Method in interface org.onosproject.net.behaviour.PipelinerContext
-
Returns the maximum number of millis between objectives before processing is triggered.
- accumulatorMaxObjectives() - Method in interface org.onosproject.net.behaviour.PipelinerContext
-
Returns the maximum number of objectives to accumulate before processing is triggered.
- ACK - org.onosproject.net.flow.criteria.Criterion.TcpFlags
-
Acknowledgment field is significant.
- acknowledge - Variable in class org.onlab.packet.TCP
- acknowledged() - Method in interface org.onosproject.alarm.Alarm
-
Returns a flag to indicate if this alarm has been acknowledged.
- acknowledged() - Method in class org.onosproject.alarm.DefaultAlarm
- action() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
- action() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
-
Action used by this token bucket for the exceeding traffic.
- action() - Method in class org.onosproject.net.flow.instructions.PiInstruction
-
Returns the protocol-independent table action defined by this instruction.
- action() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
-
Returns the action associated to this member.
- action() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
-
Returns the action of this table entry.
- action(BandwidthProfileAction.Action) - Method in class org.onosproject.net.behaviour.BandwidthProfileAction.Builder
-
Sets the type of this builder.
- action(PiActionId) - Method in interface org.onosproject.net.pi.model.PiTableModel
-
Returns the action model associated with the given ID, if present.
- ACTION - org.onosproject.net.pi.runtime.PiTableAction.Type
-
Simple action with runtime parameters set by the control plane.
- ACTION_PROFILE_GROUP - org.onosproject.net.pi.runtime.PiEntityType
-
Action profile group.
- ACTION_PROFILE_GROUP_ID - org.onosproject.net.pi.runtime.PiTableAction.Type
-
Executes the action profile group specified by the given identifier.
- ACTION_PROFILE_MEMBER - org.onosproject.net.pi.runtime.PiEntityType
-
Action profile member.
- ACTION_PROFILE_MEMBER_ID - org.onosproject.net.pi.runtime.PiTableAction.Type
-
Executes the action profile member specified by the given identifier.
- ACTION_SET - org.onosproject.net.meter.MeterFeaturesFlag
-
Support meter action in action set.
- actionProfile() - Method in interface org.onosproject.net.pi.model.PiTableModel
-
Returns the model of the action profile that implements this table.
- actionProfile() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
-
Returns the ID of the action profile where this group belong.
- actionProfile() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
-
Returns the action profile ID of this handle.
- actionProfile() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
-
Returns the identifier of the action profile.
- actionProfileId() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
-
Returns the action profile ID of this handle.
- actionProfileId() - Method in class org.onosproject.net.pi.runtime.PiGroupKey
-
Returns the action profile ID defined by this key.
- actionProfiles() - Method in interface org.onosproject.net.pi.model.PiPipelineModel
-
Returns all action profile models defined by this pipeline model.
- actionProfiles(PiActionProfileId) - Method in interface org.onosproject.net.pi.model.PiPipelineModel
-
Returns the action profile model associated with the given ID, if present.
- actions - Variable in class org.onosproject.security.Permission
- actions() - Method in interface org.onosproject.net.pi.model.PiTableModel
-
Returns the actions supported by this table.
- activate() - Method in class org.onosproject.cli.CliComponent
- activate() - Method in class org.onosproject.common.net.AbstractDeviceProvider
- activate() - Method in class org.onosproject.net.driver.AbstractIndependentDriverLoader
- activate() - Method in class org.onosproject.rest.AbstractApiDocRegistrator
- activate() - Method in class org.onosproject.store.app.DistributedApplicationStore
- activate() - Method in class org.onosproject.store.atomix.ClusterActivator
- activate() - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
- activate() - Method in class org.onosproject.ui.UiTopo2Overlay
-
Callback invoked when this overlay is activated.
- activate() - Method in class org.onosproject.ui.UiTopoOverlay
-
Callback invoked when this overlay is activated.
- activate(ApplicationId) - Method in interface org.onosproject.app.ApplicationAdminService
-
Activates the specified application.
- activate(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
-
Mark the application as active.
- activate(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
- activate(ApplicationId, String) - Method in interface org.onosproject.component.ComponentService
-
Activates the component identified by the given name.
- activateCluster() - Method in class org.onosproject.store.atomix.ClusterActivator
-
Resources needed by the cluster are now available and the Atomix cluster can be formed.
- ACTIVATED - org.onosproject.store.app.DistributedApplicationStore.InternalState
- active() - Method in enum org.onosproject.upgrade.Upgrade.Status
-
Returns whether the upgrade status is active.
- ACTIVE - org.onosproject.app.ApplicationState
-
Indicates that application is active.
- ACTIVE - org.onosproject.cluster.ControllerNode.State
-
Signifies that the instance is active and operating normally.
- ACTIVE - org.onosproject.net.Link.State
-
Signifies that a link is currently active.
- ACTIVE - org.onosproject.store.service.DistributedPrimitive.Status
-
Signifies a state wherein the primitive is operating correctly and is capable of meeting the advertised consistency and reliability guarantees.
- ACTIVE_UNKNOWN - Static variable in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
-
Active path is currently unknown.
- activeFlowEntries() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
- activeFlowEntries() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
-
Returns the number of active flow entries in this table.
- ACTSET_OUTPUT - org.onosproject.net.flow.criteria.Criterion.Type
-
Output port from action set metadata.
- add() - Method in class org.onosproject.cpman.MetricValue.Builder
-
Builds a MetricValue object.
- add() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
- add() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
- add() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
- add() - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
-
Builds the filtering objective that will be added.
- add() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
-
Builds the forwarding objective that will be added.
- add() - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
-
Builds the next objective that will be added.
- add() - Method in interface org.onosproject.net.flowobjective.Objective.Builder
-
Builds the objective that will be added.
- add() - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
- add() - Method in interface org.onosproject.net.meter.MeterRequest.Builder
-
Requests the addition of a meter.
- add(long) - Method in class org.onlab.util.Counter
-
Adds the specified number of occurrences to the counter.
- add(E) - Method in class org.onlab.util.ExtendedSet
- add(E) - Method in class org.onlab.util.UnmodifiableDeque
- add(E) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
- add(E) - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Adds the specified element to this set if it is not already present (optional operation).
- add(E) - Method in interface org.onosproject.store.service.TransactionalSet
-
Adds the specified element to this set if it is not already present (optional operation).
- add(Bandwidth) - Method in interface org.onlab.util.Bandwidth
-
Returns a Bandwidth whose value is (this + value).
- add(Frequency) - Method in class org.onlab.util.Frequency
-
Returns a Frequency whose value is (this + value).
- add(DomainIntent) - Method in class org.onosproject.net.domain.DomainIntentOperations.Builder
-
Appends a domain intent add to the current stage.
- add(Criterion) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
- add(Criterion) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
-
Adds a traffic selection criterion.
- add(FlowRule) - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
-
Appends a flow rule add to the current stage.
- add(Instruction) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- add(Instruction) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Adds an instruction to the builder.
- add(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
- add(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
- add(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
- add(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
-
Builds the filtering objective that will be added.
- add(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
-
Builds the forwarding objective that will be added.
- add(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
-
Builds the next objective that will be added.
- add(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.Objective.Builder
-
Builds the objective that will be added.
- add(Interface) - Method in interface org.onosproject.net.intf.InterfaceAdminService
-
Adds a new interface configuration to the system.
- add(Link) - Method in class org.onosproject.ui.topo.BiLinkMap
-
Adds the given link to our collection, returning the corresponding bi-link (creating one if needed necessary).
- add(McastRoute) - Method in interface org.onosproject.net.mcast.MulticastRouteService
-
Deprecated.Adds a route to the information base.
- add(PiFieldMatch) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
-
Adds a match field to the builder.
- add(UiClusterMember) - Method in class org.onosproject.ui.model.topo.UiTopology
-
Adds the given cluster member to the topology model.
- add(UiDevice) - Method in class org.onosproject.ui.model.topo.UiTopology
-
Adds the given device to the topology model.
- add(UiDeviceLink) - Method in class org.onosproject.ui.model.topo.UiTopology
-
Adds the given UI device link to the topology model.
- add(UiEdgeLink) - Method in class org.onosproject.ui.model.topo.UiTopology
-
Adds the given UI edge link to the topology model.
- add(UiHost) - Method in class org.onosproject.ui.model.topo.UiTopology
-
Adds the given host to the topology model.
- add(UiRegion) - Method in class org.onosproject.ui.model.topo.UiTopology
-
Adds the given region to the topology model.
- add(DeviceHighlight) - Method in class org.onosproject.ui.topo.Highlights
-
Adds highlighting information for a device.
- add(HostHighlight) - Method in class org.onosproject.ui.topo.Highlights
-
Adds highlighting information for a host.
- add(LinkHighlight) - Method in class org.onosproject.ui.topo.Highlights
-
Adds highlighting information for a link.
- add(T) - Method in class org.onlab.util.AbstractAccumulator
- add(T) - Method in interface org.onlab.util.Accumulator
-
Adds an item to the current batch.
- ADD - org.onosproject.net.domain.DomainIntentOperation.Type
- ADD - org.onosproject.net.flow.FlowRuleOperation.Type
- ADD - org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry.FlowRuleOperation
-
Deprecated.
- ADD - org.onosproject.net.flowobjective.Objective.Operation
-
Adds the objective.
- ADD - org.onosproject.net.flowobjective.ObjectiveEvent.Type
-
Signifies that the objective has been added to the store.
- ADD - org.onosproject.net.group.GroupOperation.Type
-
Create a group in a device with the specified parameters.
- ADD - org.onosproject.net.group.GroupStore.UpdateType
-
Modify existing group entry by adding provided information.
- ADD - org.onosproject.net.intent.IntentInstaller.Direction
-
Direction for adding any installable objects(flows, configs...).
- ADD - org.onosproject.net.mcast.McastStore.Type
-
Deprecated.Adding a route to the mcast rib.
- ADD - org.onosproject.net.meter.MeterOperation.Type
- ADD - org.onosproject.net.meter.MeterRequest.Type
- ADD - org.onosproject.store.service.SetEvent.Type
-
Entry added to the set.
- ADD_TO_EXISTING - org.onosproject.net.flowobjective.Objective.Operation
-
Add to an existing Next Objective.
- addAccessMode(String, VlanId) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
-
Adds an access interface to a VLAN.
- addActivePartitionMember(PartitionId, NodeId) - Method in interface org.onosproject.cluster.ClusterMetadataProvider
-
Adds a controller node to the list of active members for a partition.
- addAll(Collection<? extends E>) - Method in class org.onlab.util.ExtendedSet
- addAll(Collection<? extends E>) - Method in class org.onlab.util.UnmodifiableDeque
- addAll(Collection<? extends E>) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
- addAll(Collection<? extends E>) - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Adds all of the elements in the specified collection to this set if they're not already present (optional operation).
- addAll(BatchOperation<T>) - Method in class org.onosproject.net.flow.BatchOperation
-
Add all operations from another batch to this batch.
- addAndGet(long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
- addAndGet(long) - Method in interface org.onosproject.store.service.AsyncAtomicCounter
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in interface org.onosproject.store.service.AtomicCounter
-
Atomically adds the given value to the current value.
- addAndGet(K, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
- addAndGet(K, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
-
Adds delta to the value currently associated with key, and returns the new value.
- addAndGet(K, long) - Method in interface org.onosproject.store.service.AtomicCounterMap
-
Adds delta to the value currently associated with key, and returns the new value.
- addAnnotation(String, Object) - Method in class org.onosproject.ui.chart.ChartModel
-
Inserts a new annotation.
- addAnnotation(String, Object) - Method in class org.onosproject.ui.table.TableModel
-
Inserts a new annotation.
- addAttributes(Map<String, String>) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
-
Adds specified attributes.
- addBandwidthProfile(Collection<BandwidthProfile>) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
-
Adds new bandwidth profiles on the device.
- addBandwidthProfile(BandwidthProfile) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
-
Adds a new bandwidth profile on the device.
- addBehaviour(Class<? extends Behaviour>, Class<? extends Behaviour>) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf.Builder
-
Adds a behaviour to this pipeconf.
- addBridge(BridgeDescription) - Method in interface org.onosproject.net.behaviour.BridgeConfig
-
Adds a bridge with a given description.
- addBucketsToGroup(DeviceId, GroupKey, GroupBuckets, GroupKey, ApplicationId) - Method in interface org.onosproject.net.group.GroupService
-
Appends buckets to existing group.
- addButton(ButtonId) - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds the given button descriptor to the panel data.
- addChangeListener(Consumer<Change<Leadership>>) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
- addChangeListener(Consumer<Change<Leadership>>) - Method in interface org.onosproject.store.service.AsyncLeaderElector
-
Registers a listener to be notified of Leadership changes for all topics.
- addChangeListener(Consumer<Change<Leadership>>) - Method in interface org.onosproject.store.service.LeaderElector
-
Registers a listener to be notified of Leadership changes for all topics.
- addCondition(Criterion) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
- addCondition(Criterion) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
-
Add a filtering condition.
- addConfig(S, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigService
-
Creates a new configuration for the specified subject and configuration class.
- addConfig(S, Class<C>) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
- addConfigFactory(ConfigFactory) - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Adds a new configuration factory.
- addDataPlaneEntity(DataPlaneEntity) - Method in class org.onosproject.net.PipelineTraceableHitChain
-
Adds the provided dataplane entity to the end of the chain.
- addDataPoint(Object) - Method in class org.onosproject.ui.chart.ChartModel
-
Adds a data point to the chart model.
- addDeviceAgentListener(ProviderId, DeviceAgentListener) - Method in interface org.onosproject.net.device.DeviceHandshaker
-
Adds a device agent listener for the given provider ID.
- addDevices(RegionId, Collection<DeviceId>) - Method in interface org.onosproject.net.region.RegionAdminService
-
Adds the specified collection of devices to the region.
- addDevices(RegionId, Collection<DeviceId>) - Method in interface org.onosproject.net.region.RegionStore
-
Adds the specified collection of devices to the region.
- addDriver(Driver) - Method in class org.onosproject.net.driver.DefaultDriverProvider
-
Adds the specified driver to the provider.
- addDrivers(Set<Driver>) - Method in class org.onosproject.net.driver.DefaultDriverProvider
-
Adds the specified drivers to the provider.
- ADDED - org.onosproject.net.flow.FlowEntry.FlowEntryState
-
Rule has been added which means it is in the flow table.
- ADDED - org.onosproject.net.group.Group.GroupState
-
Group is created in the data plane.
- ADDED - org.onosproject.net.meter.MeterState
-
The meter has been added.
- addEdge(E) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
- addEdge(E) - Method in interface org.onlab.graph.MutableGraph
-
Adds the specified edge to this graph.
- addErrorContext(IntentOperationContext) - Method in class org.onosproject.net.intent.IntentInstallationContext
-
Adds an error context.
- addExtension(PiPipeconf.ExtensionType, URL) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf.Builder
-
Adds an extension to this pipeconf.
- addFieldMatch(PiFieldMatch) - Method in class org.onosproject.net.pi.runtime.PiMatchKey.Builder
-
Adds one field match to this match key.
- addFieldMatches(Collection<PiFieldMatch>) - Method in class org.onosproject.net.pi.runtime.PiMatchKey.Builder
-
Adds many field matches to this match key.
- addFilter(PacketInFilter) - Method in interface org.onosproject.net.packet.PacketService
-
Adds the specified filter to the list of packet filters.
- addFirst(E) - Method in class org.onlab.util.UnmodifiableDeque
- addFlowStatistic(FlowEntry) - Method in interface org.onosproject.net.statistic.FlowStatisticStore
-
Adds a flow stats observation for a flow rule.
- addGroup(IGMPGroup) - Method in class org.onlab.packet.IGMP
-
Add a multicast group to this IGMP message.
- addGroup(IGMPGroup) - Method in class org.onlab.packet.IGMP.IGMPv2
- addGroup(IGMPGroup) - Method in class org.onlab.packet.IGMP.IGMPv3
- addGroup(GroupDescription) - Method in interface org.onosproject.net.group.GroupService
-
Creates a group in the specified device with the provided buckets.
- addHitChain(PipelineTraceableHitChain) - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
-
Stores the provided hit chain.
- AddHostToHostIntentCommand - Class in org.onosproject.cli.net
-
Installs host-to-host connectivity intent.
- AddHostToHostIntentCommand() - Constructor for class org.onosproject.cli.net.AddHostToHostIntentCommand
- addInterface(Interface) - Method in class org.onosproject.net.config.basics.InterfaceConfig
-
Adds an interface to the config.
- addIntObjective(IntObjective) - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
-
Adds a given IntObjective to the device.
- addItem(String, String) - Method in class org.onosproject.ui.lion.LionBundle.Builder
-
Adds an item to the bundle.
- additionalLinkData(LinkEvent) - Method in class org.onosproject.ui.UiTopoOverlay
-
Deprecated.this is a temporary addition for Goldeneye (1.6) release, and is superceded by use of
UiTopoOverlay.modifyEdgeLinkDetails(org.onosproject.ui.topo.PropertyPanel, org.onosproject.net.HostId, org.onosproject.net.ConnectPoint)
andUiTopoOverlay.modifyInfraLinkDetails(org.onosproject.ui.topo.PropertyPanel, org.onosproject.net.ConnectPoint, org.onosproject.net.ConnectPoint)
. - addJoin(String, String) - Method in class org.onlab.packet.pim.PIMJoinPrune
-
Add a join given strings represending the source and group addresses.
- addJoinPrune(String, String, boolean) - Method in class org.onlab.packet.pim.PIMJoinPrune
-
Add the specified s,g to join field.
- addJoinPrune(IpPrefix, IpPrefix, boolean) - Method in class org.onlab.packet.pim.PIMJoinPrune
-
Add the specified S, G to the join field.
- addKey(DeviceKey) - Method in interface org.onosproject.net.key.DeviceKeyAdminService
-
Adds a new device key to the store.
- addLast(E) - Method in class org.onlab.util.UnmodifiableDeque
- addLayout(UiTopoLayout) - Method in interface org.onosproject.ui.UiTopoLayoutService
-
Adds a layout to the system or updates an existing one.
- addListener(L) - Method in class org.onosproject.event.AbstractListenerManager
- addListener(L) - Method in class org.onosproject.event.ListenerRegistry
- addListener(L) - Method in interface org.onosproject.event.ListenerService
-
Adds the specified listener.
- addListener(L) - Method in class org.onosproject.net.provider.AbstractListenerProviderRegistry
- addListener(ListenerService<E, L>, L) - Method in class org.onosproject.event.ListenerTracker
-
Adds
EventListener
to specifiedListenerService
. - addListener(NetworkConfigListener) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
- addListener(DeviceListener) - Method in class org.onosproject.net.device.DeviceServiceAdapter
- addListener(DeviceListener) - Method in class org.onosproject.net.utils.ForwardingDeviceService
- addListener(ReplicaInfoEventListener) - Method in interface org.onosproject.store.flow.ReplicaInfoService
-
Adds the specified replica placement info change listener.
- addListener(AtomicValueEventListener<V>) - Method in class org.onosproject.store.primitives.DefaultAtomicValue
- addListener(AtomicValueEventListener<V>) - Method in interface org.onosproject.store.service.AsyncAtomicValue
-
Registers the specified listener to be notified whenever the atomic value is updated.
- addListener(AtomicValueEventListener<V>) - Method in interface org.onosproject.store.service.AtomicValue
-
Registers the specified listener to be notified whenever the atomic value is updated.
- addListener(DocumentPath, DocumentTreeListener<V>) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
- addListener(DocumentPath, DocumentTreeListener<V>) - Method in interface org.onosproject.store.service.AsyncDocumentTree
-
Registers a listener to be notified when the subtree rooted at the specified path is modified.
- addListener(DocumentPath, DocumentTreeListener<V>) - Method in interface org.onosproject.store.service.DocumentTree
-
Registers a listener to be notified when a subtree rooted at the specified path is modified.
- addListener(DocumentTreeListener<V>) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
- addListener(DocumentTreeListener<V>) - Method in interface org.onosproject.store.service.AsyncDocumentTree
-
Registers a listener to be notified when the tree is modified.
- addListener(DocumentTreeListener<V>) - Method in interface org.onosproject.store.service.DocumentTree
-
Registers a listener to be notified when the tree is modified.
- addListener(EventuallyConsistentMapListener<K, V>) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
-
Adds the specified listener to the map which will be notified whenever the mappings in the map are changed.
- addListener(MapEventListener<String, V>, Executor) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- addListener(MapEventListener<K, V>) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MapEventListener<K, V>) - Method in interface org.onosproject.store.service.ConsistentMap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MapEventListener<K, V>, Executor) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- addListener(MapEventListener<K, V>, Executor) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MapEventListener<K, V>, Executor) - Method in interface org.onosproject.store.service.ConsistentMap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MultimapEventListener<K, V>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MultimapEventListener<K, V>) - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MultimapEventListener<K, V>, Executor) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
- addListener(MultimapEventListener<K, V>, Executor) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(MultimapEventListener<K, V>, Executor) - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Registers the specified listener to be notified whenever the map is updated.
- addListener(SetEventListener<E>) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
- addListener(SetEventListener<E>) - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Registers the specified listener to be notified whenever the set is updated.
- addListener(SetEventListener<E>) - Method in interface org.onosproject.store.service.DistributedSet
-
Registers the specified listener to be notified whenever the set is updated.
- addLocationToHost(HostId, HostLocation) - Method in interface org.onosproject.net.host.HostProviderService
-
Notifies the core when a location is associated with a host.
- addMember(byte[], int) - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
-
Member details adding.
- addMember(PiActionProfileGroup.WeightedMember) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Adds one member to this action profile.
- addMember(PiActionProfileMember) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Adds one member to this action profile group with default weight.
- addMember(PiActionProfileMemberId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Adds one member to this action profile group with default weight.
- addMember(PiActionProfileMemberId, int) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Adds one member to this action profile group with the given weight.
- addMember(PiActionProfileMember, int) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Adds one member to this action profile group with the given weight.
- addMembers(Iterable<PiActionProfileMember>) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Adds all members to this action profile group with default weight.
- addMessageAuthenticator(String) - Method in class org.onlab.packet.RADIUS
-
Adds a message authenticator to the packet based on the given key.
- addMetricType(String) - Method in interface org.onosproject.cpman.MetricsDatabase.Builder
-
Add a new metric to be monitored.
- addMirroring(BridgeName, MirroringDescription) - Method in interface org.onosproject.net.behaviour.MirroringConfig
-
Adds a mirroring with a given description.
- addMod(Mod) - Method in class org.onosproject.ui.topo.LinkHighlight
-
Adds a highlighting modification to this link highlight.
- addMultiple(Collection<E>) - Method in interface org.onosproject.store.service.WorkQueue
-
Adds a collection of tasks to the work queue.
- AddMultiPointToSinglePointIntentCommand - Class in org.onosproject.cli.net
-
Installs connectivity intent between multiple ingress devices and a single egress device.
- AddMultiPointToSinglePointIntentCommand() - Constructor for class org.onosproject.cli.net.AddMultiPointToSinglePointIntentCommand
- addNode(NodeId, IpAddress, int) - Method in interface org.onosproject.cluster.ClusterStore
-
Adds a new controller node to the cluster.
- addOne(E) - Method in interface org.onosproject.store.service.WorkQueue
-
Adds a single task to the work queue.
- addOperation(T) - Method in class org.onosproject.net.flow.BatchOperation
-
Adds an operation.
- addOption(byte, byte[]) - Method in class org.onlab.packet.ndp.NeighborAdvertisement
-
Adds a Neighbor Discovery Protocol packet option.
- addOption(byte, byte[]) - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
-
Adds a Neighbor Discovery Protocol packet option.
- addOption(byte, byte[]) - Method in class org.onlab.packet.ndp.NeighborSolicitation
-
Adds a Neighbor Discovery Protocol packet option.
- addOption(byte, byte[]) - Method in class org.onlab.packet.ndp.Redirect
-
Adds a Neighbor Discovery Protocol packet option.
- addOption(byte, byte[]) - Method in class org.onlab.packet.ndp.RouterAdvertisement
-
Adds a Neighbor Discovery Protocol packet option.
- addOption(byte, byte[]) - Method in class org.onlab.packet.ndp.RouterSolicitation
-
Adds a Neighbor Discovery Protocol packet option.
- addOption(PIMHelloOption) - Method in class org.onlab.packet.pim.PIMHello
-
Add a PIM Hello option to this hello message.
- addOptionalTLV(LLDPTLV) - Method in class org.onlab.packet.LLDP
-
Adds additional TLV to optionalTLVList.
- addOrUpdate(PiHandle, PiTranslatedEntity<T, E>) - Method in interface org.onosproject.net.pi.service.PiTranslationStore
-
Adds or update a mapping between the given PI entity handle and translated entity.
- addOrUpdateExtraneousGroupEntry(Group) - Method in interface org.onosproject.net.group.GroupStore
-
A group entry that is present in switch but not in the store.
- addOrUpdateFlowRule(FlowEntry) - Method in interface org.onosproject.net.flow.FlowRuleStore
-
Stores a new flow rule, or updates an existing entry.
- addOrUpdateGroupEntry(Group) - Method in interface org.onosproject.net.group.GroupStore
-
Stores a new group entry, or updates an existing entry.
- addOrUpdateStatistic(FlowEntry) - Method in interface org.onosproject.net.statistic.StatisticStore
-
Adds a stats observation for a flow rule.
- addParameterSet(short, EAPOLMkpduParameterSet) - Method in class org.onlab.packet.EAPOLMkpdu
-
Populate various Parameter Sets to store.
- addPatchMode(String, PatchDescription) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
-
Adds a patch mode to the supplied interface.
- addPeerLocMapping(String, String, Double, Double) - Method in class org.onosproject.net.config.basics.BasicRegionConfig
-
Adds a peer location mapping to this region.
- addPeerToSpeaker(String, IpAddress) - Method in class org.onosproject.routing.config.BgpConfig
-
Adds peering address to BGP speaker.
- addPending(IntentData) - Method in interface org.onosproject.net.intent.IntentService
-
Adds an intent data object to the pending map for processing.
- addPending(IntentData) - Method in interface org.onosproject.net.intent.IntentStore
-
Adds a new operation, which should be persisted and delegated.
- addPendingContext(IntentOperationContext) - Method in class org.onosproject.net.intent.IntentInstallationContext
-
Adds a pending context.
- addPendingHostLocation(HostId, ConnectPoint, ProbeMode) - Method in interface org.onosproject.net.host.HostStore
-
Notifies HostStore the beginning of pending host location verification and retrieves the unique MAC address for the probe.
- AddPointToPointIntentCommand - Class in org.onosproject.cli.net
-
Installs point-to-point connectivity intents.
- AddPointToPointIntentCommand() - Constructor for class org.onosproject.cli.net.AddPointToPointIntentCommand
- addPolicer(Policer) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerConfigurable
- addPort(BridgeName, String) - Method in interface org.onosproject.net.behaviour.BridgeConfig
-
Adds a port to a given bridge.
- addProbingHost(Host, ConnectPoint, ProbeMode, MacAddress, int) - Method in interface org.onosproject.net.host.HostProbeStore
-
Notifies HostProbeStore the beginning of pending host location verification and retrieves the unique MAC address for the probe.
- addProbingHost(Host, ConnectPoint, ProbeMode, MacAddress, int) - Method in interface org.onosproject.net.host.HostProbingProviderService
-
Notifies HostProbeStore the beginning of pending host location verification and retrieves the unique MAC address for the probe.
- addProcessor(PacketProcessor, int) - Method in interface org.onosproject.net.packet.PacketService
-
Adds the specified processor to the list of packet processors.
- addProp(String, String, int) - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds a property to the panel data, using a decimal formatter.
- addProp(String, String, long) - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds a property to the panel data, using a decimal formatter.
- addProp(String, String, Object) - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds a property to the panel data.
- addProp(String, String, Object, String) - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds a property to the panel data.
- addProp(String, String, String) - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds a property to the panel data.
- AddProtectedTransportIntentCommand - Class in org.onosproject.cli.net
-
Installs ProtectedTransportIntent.
- AddProtectedTransportIntentCommand() - Constructor for class org.onosproject.cli.net.AddProtectedTransportIntentCommand
- addPrune(String, String) - Method in class org.onlab.packet.pim.PIMJoinPrune
-
Add a prune given strings represending the source and group addresses.
- addQoS(QosDescription) - Method in interface org.onosproject.net.behaviour.QosConfigBehaviour
-
create QoS configuration on a device.
- addQueue(QueueDescription) - Method in interface org.onosproject.net.behaviour.QueueConfigBehaviour
-
Create a queue to a device.
- ADDR_UNREACH - org.onosproject.cli.net.Icmp6Code
-
Address unreachable.
- ADDR_UNREACH - Static variable in class org.onlab.packet.ICMP6
-
Address unreachable.
- addRateLimit(String, short) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
-
Adds a rate limit on an interface.
- addRegistration(String) - Method in interface org.onosproject.cluster.LeadershipStore
-
Adds registration for the local instance to be part of the leadership contest for topic.
- addReplica(PiPreReplica) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry.Builder
-
Adds the given packet replica to this clone session.
- addReplica(PiPreReplica) - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry.Builder
-
Adds the given packet replica to this multicast group.
- addReplicas(Collection<PiPreReplica>) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry.Builder
-
Adds the given packet replicas to this clone session.
- addReplicas(Collection<PiPreReplica>) - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry.Builder
-
Adds the given packet replicas to this multicast group.
- address() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
-
To return address.
- address() - Method in class org.onlab.packet.Ip4Prefix
-
Returns the IPv4 address value of the prefix.
- address() - Method in class org.onlab.packet.Ip6Prefix
-
Returns the IPv6 address value of the prefix.
- address() - Method in class org.onlab.packet.IpPrefix
-
Returns the IP address value of the prefix.
- address() - Method in class org.onosproject.routing.NextHopGroupKey
-
Returns the next hop's IP address.
- ADDRESS_FAMILY_IP4 - Static variable in class org.onlab.packet.PIM
- ADDRESS_FAMILY_IP6 - Static variable in class org.onlab.packet.PIM
- addressFamilyId - Variable in class org.onlab.packet.RIPV2AuthEntry
- addressFamilyId - Variable in class org.onlab.packet.RIPV2Entry
- addRow() - Method in class org.onosproject.ui.table.TableModel
-
Adds a row to the table model.
- addSeparator() - Method in class org.onosproject.ui.topo.PropertyPanel
-
Adds a separator to the panel data.
- AddSinglePointToMultiPointIntentCommand - Class in org.onosproject.cli.net
-
Installs connectivity intent between a single ingress device and multiple egress devices.
- AddSinglePointToMultiPointIntentCommand() - Constructor for class org.onosproject.cli.net.AddSinglePointToMultiPointIntentCommand
- addSink(Class<E>, EventSink<E>) - Method in class org.onosproject.event.DefaultEventSinkRegistry
- addSink(Class<E>, EventSink<E>) - Method in interface org.onosproject.event.EventSinkRegistry
-
Adds the specified sink for the given event class.
- addSink(McastRoute, ConnectPoint) - Method in interface org.onosproject.net.mcast.MulticastRouteService
-
Deprecated.Adds a sink to the route to which a data stream should be sent to.
- addSource(IpAddress) - Method in class org.onlab.packet.IGMPGroup
-
Add a unicast source address to this message.
- addSource(McastRoute, ConnectPoint) - Method in interface org.onosproject.net.mcast.MulticastRouteService
-
Deprecated.Adds a source connection to the route from where the data stream is originating.
- addSpeaker(BgpConfig.BgpSpeakerConfig) - Method in class org.onosproject.routing.config.BgpConfig
-
Adds a BGP speaker to the configuration.
- addStatusChangeListener(Consumer<DistributedPrimitive.Status>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- addStatusChangeListener(Consumer<DistributedPrimitive.Status>) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
- addStatusChangeListener(Consumer<DistributedPrimitive.Status>) - Method in interface org.onosproject.store.service.DistributedPrimitive
-
Registers a listener to be called when the primitive's status changes.
- addSubOption(DhcpOption) - Method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
-
Adds a sub-option for this option.
- addSubscriber(MessageSubject, Function<byte[], M>, Consumer<M>, Executor) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
-
Adds a new subscriber for the specified message subject.
- addSubscriber(MessageSubject, Function<byte[], M>, Function<M, CompletableFuture<R>>, Function<R, byte[]>) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
-
Adds a new subscriber for the specified message subject.
- addSubscriber(MessageSubject, Function<byte[], M>, Function<M, R>, Function<R, byte[]>, Executor) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
-
Adds a new subscriber for the specified message subject.
- addSubscriber(MessageSubject, ClusterMessageHandler, ExecutorService) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
-
Deprecated.in Cardinal Release
- addTableConfigAnnotations(TableModel, ObjectNode) - Method in class org.onosproject.ui.table.TableRequestHandler
-
Adds table configuration specific annotations to table model.
- AddTestFlowsCommand - Class in org.onosproject.cli.net
-
Installs bulk flows.
- AddTestFlowsCommand() - Constructor for class org.onosproject.cli.net.AddTestFlowsCommand
- addToExisting() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
- addToExisting() - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
-
Build the next objective that will be added, with
Objective.Operation
ADD_TO_EXISTING. - addToExisting(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
- addToExisting(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
-
Builds the next objective that will be added, with
Objective.Operation
ADD_TO_EXISTING. - addTrackedResources(Key, Collection<NetworkResource>) - Method in interface org.onosproject.net.intent.ObjectiveTrackerService
-
Adds a path flow to be tracked.
- addTreatment(TrafficTreatment) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- addTreatment(TrafficTreatment) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Add all instructions from another treatment.
- addTreatment(TrafficTreatment) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
- addTreatment(TrafficTreatment) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
-
Deprecated.in 1.14.2, replaced by
NextObjective.Builder.addTreatment(NextTreatment)
- addTreatment(NextTreatment) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
- addTreatment(NextTreatment) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
-
Adds a next treatment to this next step.
- addTrunkMode(String, List<VlanId>) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
-
Adds a trunk interface for VLANs.
- addTunnelMode(String, TunnelDescription) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
-
Adds a tunnel mode to supplied interface.
- addVertex(V) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
- addVertex(V) - Method in interface org.onlab.graph.MutableGraph
-
Adds the specified vertex to this graph.
- addVlan(Collection<VlanId>) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
-
Adds VLANs on a device.
- addVlan(VlanId) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
-
Adds a VLAN on a device.
- AdjacencyListsGraph<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Immutable graph implemented using adjacency lists.
- AdjacencyListsGraph(Set<V>, Set<E>) - Constructor for class org.onlab.graph.AdjacencyListsGraph
-
Creates a graph comprising of the specified vertexes and edges.
- ADMIN - org.onosproject.core.ApplicationRole
-
Indicates that an application has an ADMIN role.
- ADMIN_STATE - Static variable in class org.onosproject.net.AnnotationKeys
-
Annotation key for the admin state.
- ADVERTISE - org.onlab.packet.DHCP6.MsgType
- advisor(int) - Static method in interface org.onosproject.net.packet.PacketProcessor
-
Returns a priority in the ADVISOR range, where processors can take early action and influence the packet context.
- ADVISOR_MAX - Static variable in interface org.onosproject.net.packet.PacketProcessor
- AF11 - org.onlab.packet.DscpClass
- AF12 - org.onlab.packet.DscpClass
- AF13 - org.onlab.packet.DscpClass
- AF21 - org.onlab.packet.DscpClass
- AF22 - org.onlab.packet.DscpClass
- AF23 - org.onlab.packet.DscpClass
- AF31 - org.onlab.packet.DscpClass
- AF32 - org.onlab.packet.DscpClass
- AF33 - org.onlab.packet.DscpClass
- AF41 - org.onlab.packet.DscpClass
- AF42 - org.onlab.packet.DscpClass
- AF43 - org.onlab.packet.DscpClass
- AFI_IP - Static variable in class org.onlab.packet.RIPV2Entry
- afterExecute(Runnable, Throwable) - Method in class org.onlab.util.BoundedThreadPool
- age() - Method in class org.onosproject.net.group.DefaultGroup
- age() - Method in interface org.onosproject.net.group.Group
-
Obtains the age of a group.
- Alarm - Interface in org.onosproject.alarm
-
Representation of an Alarm.
- Alarm.SeverityLevel - Enum in org.onosproject.alarm
-
Represents the severity level on an alarm, as per ITU-T X.733 specifications.
- AlarmConsumer - Interface in org.onosproject.alarm
-
Abstraction of a device behaviour capable of retrieving/consuming list of pending alarms from the device.
- alarmEntityId(String) - Static method in class org.onosproject.alarm.AlarmEntityId
- alarmEntityId(URI) - Static method in class org.onosproject.alarm.AlarmEntityId
- AlarmEntityId - Class in org.onosproject.alarm
-
Immutable representation of a alarm source.
- AlarmEntityId() - Constructor for class org.onosproject.alarm.AlarmEntityId
- AlarmEvent - Class in org.onosproject.alarm
-
Entity that represents Alarm events.
- AlarmEvent(AlarmEvent.Type, Alarm) - Constructor for class org.onosproject.alarm.AlarmEvent
-
Creates an event due to one alarm.
- AlarmEvent.Type - Enum in org.onosproject.alarm
-
Type of alarm event.
- alarmId(String) - Static method in class org.onosproject.alarm.AlarmId
-
Creates an alarm identifier from the specified globally unique identifier.
- alarmId(DeviceId, String) - Static method in class org.onosproject.alarm.AlarmId
-
Creates an alarm identifier from the specified device id and unique identifier provided representation.
- AlarmId - Class in org.onosproject.alarm
-
Alarm identifier suitable as an external key.
- AlarmListener - Interface in org.onosproject.alarm
-
Entity capable of receiving alarm related events.
- AlarmProvider - Interface in org.onosproject.alarm
-
Abstraction of an entity capable of supplying alarms collected from network devices.
- AlarmProviderRegistry - Interface in org.onosproject.alarm
-
Abstraction of a alarm provider registry.
- AlarmProviderService - Interface in org.onosproject.alarm
-
The interface Alarm provider service.
- AlarmService - Interface in org.onosproject.alarm
-
Service for interacting with the alarm handling of devices.
- AlarmTranslator - Interface in org.onosproject.alarm
-
Abstraction of ability to translate device messages into alarms.
- all() - Method in interface org.onosproject.cpman.ControlLoad
-
Obtains all metrics.
- ALL - org.onosproject.net.Direction
- ALL - org.onosproject.net.group.GroupDescription.Type
-
Multicast to all buckets in a group.
- ALL - org.onosproject.net.PortNumber.Logical
- ALL - Static variable in class org.onosproject.net.meter.MeterId
-
Represents all meters for stat requests commands.
- ALL - Static variable in class org.onosproject.net.PortNumber
- ALL_DHCP_RELAY_AGENTS_AND_SERVERS - Static variable in class org.onlab.packet.Ip6Address
-
A link-scoped multicast address used by a DHCP client to communicate with neighboring DHCP relay agents and servers.
- ALL_DHCP_SERVERS - Static variable in class org.onlab.packet.Ip6Address
-
A site-scoped multicast address used by a DHCP relay agent to communicate with DHCP servers.
- ALL_PATHS - Static variable in interface org.onlab.graph.GraphPathSearch
- ALL_RIP_ROUTERS - Static variable in class org.onlab.packet.Ip6Address
-
All RIP routers multicast group.
- ALL_TRAFFIC - Static variable in class org.onosproject.ui.GlyphConstants
- AllApplicationNamesCompleter - Class in org.onosproject.cli.app
-
All installed application name completer.
- AllApplicationNamesCompleter() - Constructor for class org.onosproject.cli.app.AllApplicationNamesCompleter
- allClusterMembers() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Returns all the cluster members, sorted by their ID.
- allDeviceLinks() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Returns all device links in the model.
- allDevices() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Returns all devices in the model.
- allHosts() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Returns all hosts in the model.
- allInstructions() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
- allInstructions() - Method in interface org.onosproject.net.flow.TrafficTreatment
-
Returns the list of all instructions in the treatment, both immediate and deferred.
- allocate(List<? extends Resource>, ResourceConsumer) - Method in interface org.onosproject.net.resource.ResourceStore
-
Allocates the specified resources to the specified consumer in transactional way.
- allocate(ResourceConsumer, List<? extends Resource>) - Method in interface org.onosproject.net.resource.ResourceService
-
Transactionally allocates the specified resources to the specified user.
- allocate(ResourceConsumer, Resource) - Method in interface org.onosproject.net.resource.ResourceService
-
Allocates the specified resource to the specified user.
- allocate(ResourceConsumer, Resource...) - Method in interface org.onosproject.net.resource.ResourceService
-
Transactionally allocates the specified resources to the specified user.
- allocateMapping(IntentId, IntentId) - Method in interface org.onosproject.net.intent.IntentSetMultimap
-
Allocates the mapping between the given intents.
- allocateMeterId(DeviceId) - Method in interface org.onosproject.net.meter.MeterService
-
Allocates a new meter id in the system.
- allocateMeterId(DeviceId) - Method in interface org.onosproject.net.meter.MeterStore
-
Allocates the first available MeterId.
- allocateNextId() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
-
Obtains a globally unique next objective.
- allocateNextId() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveStore
-
Allocates a next objective id.
- allocatePolicerId() - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerConfigurable
-
Allocates a new policer id.
- AllocationsCommand - Class in org.onosproject.cli.net
-
Lists allocated resources.
- AllocationsCommand() - Constructor for class org.onosproject.cli.net.AllocationsCommand
- allOf(List<CompletableFuture<T>>) - Static method in class org.onlab.util.Tools
-
Returns a new CompletableFuture completed with a list of computed values when all of the given CompletableFuture complete.
- allOf(List<CompletableFuture<T>>, BinaryOperator<T>, T) - Static method in class org.onlab.util.Tools
-
Returns a new CompletableFuture completed by reducing a list of computed values when all of the given CompletableFuture complete.
- ALLOW_EXTRANEOUS_GROUPS - Static variable in class org.onosproject.store.OsgiPropertyConstants
- ALLOW_EXTRANEOUS_GROUPS_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
- ALLOW_EXTRANEOUS_RULES - Static variable in class org.onosproject.net.OsgiPropertyConstants
- ALLOW_EXTRANEOUS_RULES_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
- ALLOW_NEW_SOURCES - Static variable in class org.onlab.packet.IGMPMembership
- ALLOWED - Static variable in class org.onosproject.net.config.basics.AllowedEntityConfig
- AllowedEntityConfig<S> - Class in org.onosproject.net.config.basics
-
Base abstraction for network entities for which admission into control domain can be selectively configured, e.g.
- AllowedEntityConfig() - Constructor for class org.onosproject.net.config.basics.AllowedEntityConfig
- allRegions() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Returns all regions in the model (except the
null region
). - AND - org.onlab.util.StringFilter.Strategy
- Annot(String, Object) - Constructor for class org.onosproject.ui.chart.ChartModel.Annot
-
Constructs an annotation with the given key and value.
- Annot(String, Object) - Constructor for class org.onosproject.ui.table.TableModel.Annot
-
Constructs an annotation with the given key and value.
- Annotated - Interface in org.onosproject.net
-
Represents an entity that carries arbitrary annotations.
- AnnotateDeviceCommand - Class in org.onosproject.cli.net
-
Annotates network device model.
- AnnotateDeviceCommand() - Constructor for class org.onosproject.cli.net.AnnotateDeviceCommand
- AnnotateHostCommand - Class in org.onosproject.cli.net
-
Annotates host model.
- AnnotateHostCommand() - Constructor for class org.onosproject.cli.net.AnnotateHostCommand
- AnnotateLinkCommand - Class in org.onosproject.cli.net
-
Annotates network link model.
- AnnotateLinkCommand() - Constructor for class org.onosproject.cli.net.AnnotateLinkCommand
- AnnotatePortCommand - Class in org.onosproject.cli.net
-
Annotates network device port model.
- AnnotatePortCommand() - Constructor for class org.onosproject.cli.net.AnnotatePortCommand
- annotation(String) - Method in class org.onosproject.net.config.basics.DeviceAnnotationConfig
-
Remove configuration about specified key.
- annotation(String) - Method in class org.onosproject.net.config.basics.HostAnnotationConfig
-
Remove configuration about specified key.
- annotation(String) - Method in class org.onosproject.net.config.basics.PortAnnotationConfig
-
Remove configuration about specified key.
- annotation(String, String) - Method in class org.onosproject.net.config.basics.DeviceAnnotationConfig
-
Add configuration to set or remove annotation entry.
- annotation(String, String) - Method in class org.onosproject.net.config.basics.HostAnnotationConfig
-
Add configuration to set or remove annotation entry.
- annotation(String, String) - Method in class org.onosproject.net.config.basics.PortAnnotationConfig
-
Add configuration to set or remove annotation entry.
- AnnotationConstraint - Class in org.onosproject.net.intent.constraint
-
Constraint that evaluates an arbitrary link annotated value is under the specified threshold.
- AnnotationConstraint(String, double) - Constructor for class org.onosproject.net.intent.constraint.AnnotationConstraint
-
Creates a new constraint to keep the value for the specified key of link annotation under the threshold.
- AnnotationDriverData() - Constructor for class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
- AnnotationKeys - Class in org.onosproject.net
-
Collection of keys for annotation.
- AnnotationKeysCompleter - Class in org.onosproject.cli.net.completer
-
Completer for annotation keys declared in
AnnotationKeys
. - AnnotationKeysCompleter() - Constructor for class org.onosproject.cli.net.completer.AnnotationKeysCompleter
- annotations() - Method in class org.onosproject.net.AbstractAnnotated
- annotations() - Method in class org.onosproject.net.AbstractDescription
- annotations() - Method in interface org.onosproject.net.Annotated
-
Returns the key/value annotations.
- annotations() - Method in class org.onosproject.net.behaviour.ControllerInfo
- annotations() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
- annotations() - Method in class org.onosproject.net.config.basics.DeviceAnnotationConfig
-
Returns annotations to add to a Device.
- annotations() - Method in class org.onosproject.net.config.basics.HostAnnotationConfig
-
Returns annotations to add to a Host.
- annotations() - Method in class org.onosproject.net.config.basics.PortAnnotationConfig
-
Returns annotations to add to a Port.
- annotations() - Method in interface org.onosproject.net.Description
- annotations() - Method in interface org.onosproject.net.device.PortStatistics
- annotations() - Method in interface org.onosproject.net.utils.ForwardingDevice
- annotations() - Method in class org.onosproject.net.utils.ForwardingPort
- annotations(ObjectMapper, Annotations) - Static method in class org.onosproject.cli.AbstractShellCommand
-
Produces a JSON object from the specified key/value annotations.
- annotations(Map<String, String>) - Method in class org.onosproject.net.config.basics.DeviceAnnotationConfig
-
Sets annotations to add to a Device.
- annotations(Map<String, String>) - Method in class org.onosproject.net.config.basics.HostAnnotationConfig
-
Sets annotations to add to a Host.
- annotations(Map<String, String>) - Method in class org.onosproject.net.config.basics.PortAnnotationConfig
-
Sets annotations to add to a Port.
- annotations(Annotations) - Static method in class org.onosproject.cli.AbstractShellCommand
-
Produces a string image of the specified key/value annotations.
- annotations(Annotations) - Method in class org.onosproject.net.DefaultLink.Builder
-
Sets the annotations to be used by the builder.
- annotations(Annotations, Set<String>) - Static method in class org.onosproject.cli.AbstractShellCommand
-
Produces a string image of the specified key/value annotations.
- annotations(SparseAnnotations) - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
-
Sets annotations.
- Annotations - Interface in org.onosproject.net
-
Represents an set of simple key/value string annotations.
- AnnotationsSerializer - Class in org.onosproject.store.serializers
- AnnotationsSerializer() - Constructor for class org.onosproject.store.serializers.AnnotationsSerializer
- AnnotationsUtil - Class in org.onosproject.net
-
Utility for processing annotations.
- anoint(String, NodeId) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
- anoint(String, NodeId) - Method in interface org.onosproject.store.service.AsyncLeaderElector
-
Attempts to promote a node to leadership displacing the current leader.
- anoint(String, NodeId) - Method in interface org.onosproject.store.service.LeaderElector
-
Attempts to promote a node to leadership displacing the current leader.
- ANTI_ENTROPY_PERIOD_MILLIS - Static variable in class org.onosproject.store.OsgiPropertyConstants
- ANTI_ENTROPY_PERIOD_MILLIS_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
- any() - Static method in class org.onlab.util.Match
-
Returns a Match that matches any value including null.
- ANY - org.onosproject.net.PortNumber.Logical
- ANY - Static variable in class org.onlab.packet.VlanId
- ANY - Static variable in class org.onlab.util.Match
- ANY - Static variable in class org.onosproject.cli.net.FlowsListCommand
- ANY - Static variable in class org.onosproject.cli.net.GroupsListCommand
- ANY - Static variable in class org.onosproject.net.PortNumber
- ANY_POSITION - org.onosproject.net.meter.MeterFeaturesFlag
-
Support any position in action list.
- ANY_VALUE - Static variable in class org.onlab.packet.VlanId
- API - Static variable in class org.onosproject.store.serializers.KryoNamespaces
-
WARNING: Do not change ordering of registrations! Serial IDs are automatically assigned to types registered via the
KryoNamespace
API. - API_MAX_SIZE - Static variable in class org.onosproject.store.serializers.KryoNamespaces
-
KryoNamespace which can serialize API bundle classes.
- ApiDocProvider - Class in org.onosproject.rest
-
Entity capable of providing REST API documentation resources.
- ApiDocProvider(String, String, ClassLoader) - Constructor for class org.onosproject.rest.ApiDocProvider
-
Creates a new REST API documentation provider.
- ApiDocService - Interface in org.onosproject.rest
-
Service for registering REST API documentation resources.
- APP_ACTIVATED - org.onosproject.app.ApplicationEvent.Type
-
Signifies that an application has been activated.
- APP_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
- APP_DEACTIVATED - org.onosproject.app.ApplicationEvent.Type
-
Signifies that an application has been deactivated.
- APP_EVENT - org.onosproject.security.AppPermission.Type
- APP_ID_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
- APP_INSTALLED - org.onosproject.app.ApplicationEvent.Type
-
Signifies that an application has been installed.
- APP_PERMISSIONS_CHANGED - org.onosproject.app.ApplicationEvent.Type
-
Signifies that application granted permissions have changed.
- APP_READ - org.onosproject.security.AppPermission.Type
- APP_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
-
Application ID subject factory.
- APP_UNINSTALLED - org.onosproject.app.ApplicationEvent.Type
-
Signifies that an application has been uninstalled.
- APP_WRITE - org.onosproject.security.AppPermission.Type
- appCookie() - Method in class org.onosproject.net.group.DefaultGroupDescription
-
Returns application cookie associated with a group object.
- appCookie() - Method in interface org.onosproject.net.group.GroupDescription
-
Returns application cookie associated with a group object.
- append(List<String>) - Method in class org.onosproject.store.service.DocumentPath
-
Creates a new DocumentPath element appending
childElm
to this path. - appendEdge(E) - Method in class org.onlab.graph.DefaultMutablePath
- appendEdge(E) - Method in interface org.onlab.graph.MutablePath
-
Appends a new edge at the end of the this path.
- appendLocation(HostId, HostLocation) - Method in interface org.onosproject.net.host.HostStore
-
Append the specified location to the host entry.
- appendToLog(String) - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
-
Appends a message to the log.
- AppGuard - Class in org.onosproject.security
-
Aids SM-ONOS to perform API-level permission checking.
- appId - Variable in class org.onosproject.net.intent.Intent.Builder
- appId() - Method in class org.onosproject.cli.AbstractShellCommand
-
Returns application ID for the CLI.
- appId() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
- appId() - Method in class org.onosproject.cli.net.RandomIntentCommand
- appId() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
-
Returns the application that is responsible for managing the attachment.
- appId() - Method in class org.onosproject.net.flow.DefaultFlowRule
- appId() - Method in interface org.onosproject.net.flow.FlowRule
-
Returns the application id of this flow.
- appId() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
- appId() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
- appId() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
- appId() - Method in interface org.onosproject.net.flowobjective.Objective
-
The application which applied this objective.
- appId() - Method in class org.onosproject.net.group.DefaultGroupDescription
-
Returns application identifier that has created this group object.
- appId() - Method in interface org.onosproject.net.group.GroupDescription
-
Returns application identifier that has created this group object.
- appId() - Method in class org.onosproject.net.intent.Intent
-
Returns the identifier of the application that requested the intent.
- appId() - Method in class org.onosproject.net.meter.DefaultMeter
- appId() - Method in class org.onosproject.net.meter.DefaultMeterRequest
- appId() - Method in interface org.onosproject.net.meter.Meter
-
The id of the application which created this meter.
- appId() - Method in interface org.onosproject.net.meter.MeterRequest
-
The id of the application which created this meter.
- appId() - Method in interface org.onosproject.net.neighbour.NeighbourHandlerRegistration
-
Gets the ID of the application that registered the handler.
- appId() - Method in class org.onosproject.net.packet.DefaultPacketRequest
- appId() - Method in interface org.onosproject.net.packet.PacketRequest
-
Obtains the application id.
- appId(ApplicationId) - Method in class org.onosproject.net.domain.DomainIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.ConnectivityIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.Intent.Builder
-
Sets the application id for the intent that will be built.
- appId(ApplicationId) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.PathIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
- appId(ApplicationId) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
- AppIdFormatter - Class in org.onosproject.ui.table.cell
-
Formats an application identifier as "(app-id) : (app-name)".
- Application - Interface in org.onosproject.core
-
Abstraction of a network control/management application.
- ApplicationAdminService - Interface in org.onosproject.app
-
Service for managing network control applications.
- ApplicationArchive - Class in org.onosproject.common.app
-
Facility for reading application archive stream and managing application directory structure.
- ApplicationArchive() - Constructor for class org.onosproject.common.app.ApplicationArchive
- ApplicationCommand - Class in org.onosproject.cli.app
-
Manages application inventory.
- ApplicationCommand() - Constructor for class org.onosproject.cli.app.ApplicationCommand
- ApplicationCommandCompleter - Class in org.onosproject.cli.app
-
Application command completer.
- ApplicationCommandCompleter() - Constructor for class org.onosproject.cli.app.ApplicationCommandCompleter
- ApplicationDescription - Interface in org.onosproject.app
-
Description of a network control/management application.
- ApplicationEvent - Class in org.onosproject.app
-
Describes application lifecycle event.
- ApplicationEvent(ApplicationEvent.Type, Application) - Constructor for class org.onosproject.app.ApplicationEvent
-
Creates an event of a given type and for the specified app and the current time.
- ApplicationEvent(ApplicationEvent.Type, Application, long) - Constructor for class org.onosproject.app.ApplicationEvent
-
Creates an event of a given type and for the specified app and time.
- ApplicationEvent.Type - Enum in org.onosproject.app
- ApplicationException - Exception in org.onosproject.app
-
Represents class of errors related to application management.
- ApplicationException() - Constructor for exception org.onosproject.app.ApplicationException
-
Constructs an exception with no message and no underlying cause.
- ApplicationException(String) - Constructor for exception org.onosproject.app.ApplicationException
-
Constructs an exception with the specified message.
- ApplicationException(String, Throwable) - Constructor for exception org.onosproject.app.ApplicationException
-
Constructs an exception with the specified message and the underlying cause.
- applicationId() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
- applicationId() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
-
The id of the application which created this policer.
- applicationId() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
-
Returns the application identifier.
- applicationId() - Method in interface org.onosproject.store.service.DistributedPrimitive
-
Returns the application owning this primitive.
- ApplicationId - Interface in org.onosproject.core
-
Application identifier.
- ApplicationIdListCommand - Class in org.onosproject.cli.app
-
Lists application ID information.
- ApplicationIdListCommand() - Constructor for class org.onosproject.cli.app.ApplicationIdListCommand
- ApplicationIdStore - Interface in org.onosproject.app
-
Manages application IDs.
- ApplicationIdStoreAdapter - Class in org.onosproject.app
-
Adapter for testing against app id store.
- ApplicationIdStoreAdapter() - Constructor for class org.onosproject.app.ApplicationIdStoreAdapter
- ApplicationIdWithIntentNameCompleter - Class in org.onosproject.cli.app
-
Application name completer.
- ApplicationIdWithIntentNameCompleter() - Constructor for class org.onosproject.cli.app.ApplicationIdWithIntentNameCompleter
- ApplicationListener - Interface in org.onosproject.app
-
Entity capable of receiving application related events.
- ApplicationNameCompleter - Class in org.onosproject.cli.app
-
Application name completer.
- ApplicationNameCompleter() - Constructor for class org.onosproject.cli.app.ApplicationNameCompleter
- ApplicationRole - Enum in org.onosproject.core
- ApplicationService - Interface in org.onosproject.app
-
Service for inspecting inventory of network control applications.
- ApplicationsListCommand - Class in org.onosproject.cli.app
-
Lists application information.
- ApplicationsListCommand() - Constructor for class org.onosproject.cli.app.ApplicationsListCommand
- ApplicationState - Enum in org.onosproject.app
-
Representation of an application state.
- ApplicationStore - Interface in org.onosproject.app
-
Service for managing network control applications.
- ApplicationStoreDelegate - Interface in org.onosproject.app
-
Application store delegate abstraction.
- apply() - Method in class org.onosproject.net.config.Config
-
Applies any configuration changes made via this configuration.
- apply(ControllerNode) - Method in class org.onosproject.cluster.ControllerNodeToNodeId
- apply(DeviceId, Objective) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
-
Installs the objective onto the specified device.
- apply(FlowRuleOperations) - Method in interface org.onosproject.net.flow.FlowRuleService
-
Applies a batch operation of FlowRules.
- apply(IntentOperationContext<T>) - Method in interface org.onosproject.net.intent.IntentInstaller
-
Applies an Intent operation context.
- apply(PipelineTraceableInput) - Method in interface org.onosproject.net.behaviour.PipelineTraceable
-
Applies pipeline processing on the given ingress state.
- apply(U) - Method in class org.onlab.util.RetryingFunction
- applyConfig(String, S, String, JsonNode) - Method in interface org.onosproject.net.config.NetworkConfigService
-
Applies configuration for the specified subject and configuration key using the raw JSON object.
- applyConfig(String, S, String, JsonNode) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
- applyConfig(S, Class<C>, JsonNode) - Method in interface org.onosproject.net.config.NetworkConfigService
-
Applies configuration for the specified subject and configuration class using the raw JSON node.
- applyConfig(S, Class<C>, JsonNode) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
- applyConfig(S, Class<C>, JsonNode) - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Applies configuration for the specified subject and configuration class using the raw JSON object.
- applyFlowRule(FlowRule...) - Method in interface org.onosproject.net.flow.FlowRuleProvider
-
Instructs the provider to apply the specified flow rules to their respective devices.
- applyFlowRules(Collection<FlowRule>) - Method in interface org.onosproject.net.flow.FlowRuleProgrammable
-
Applies the specified collection of flow rules to the device.
- applyFlowRules(FlowRule...) - Method in interface org.onosproject.net.flow.FlowRuleService
-
Applies the specified flow rules onto their respective devices.
- applyQoS(PortDescription, QosDescription) - Method in interface org.onosproject.net.behaviour.PortConfigBehaviour
-
Apply QoS configuration on a device.
- applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class org.onlab.util.BlockingAwareFuture
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class org.onlab.util.BlockingAwareFuture
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
- applyTreatmentOnEgress() - Method in class org.onosproject.net.intent.LinkCollectionIntent
-
Returns whether treatment should be applied on egress.
- applyTreatmentOnEgress(boolean) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
-
Sets the intent to apply treatment at the egress rather than the ingress.
- AppPermission - Class in org.onosproject.security
-
Implementation of API access permission.
- AppPermission(String) - Constructor for class org.onosproject.security.AppPermission
-
Creates new application permission using the supplied data.
- AppPermission(String, String) - Constructor for class org.onosproject.security.AppPermission
-
Creates new application permission using the supplied data.
- AppPermission(AppPermission.Type) - Constructor for class org.onosproject.security.AppPermission
-
Crates new application permission using the supplied data.
- AppPermission.Type - Enum in org.onosproject.security
- ARP - Class in org.onlab.packet
-
Representation of an ARP Packet.
- ARP - org.onlab.packet.EthType.EtherType
- ARP - org.onosproject.cli.net.EthType
-
ARP.
- ARP - org.onosproject.net.neighbour.NeighbourProtocol
-
Address Resolution Protocol (IPv4).
- ARP() - Constructor for class org.onlab.packet.ARP
- ARP_OP - org.onosproject.net.flow.criteria.Criterion.Type
-
ARP opcode.
- ARP_OP - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
-
Arp operation modification.
- ARP_SHA - org.onosproject.net.flow.criteria.Criterion.Type
-
ARP source hardware address.
- ARP_SHA - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
-
ARP Ether src modification.
- ARP_SPA - org.onosproject.net.flow.criteria.Criterion.Type
-
ARP source IPv4 address.
- ARP_SPA - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
-
ARP IP src modification.
- ARP_THA - org.onosproject.net.flow.criteria.Criterion.Type
-
ARP target hardware address.
- ARP_TPA - org.onosproject.net.flow.criteria.Criterion.Type
-
ARP target IPv4 address.
- ArpHaCriterion - Class in org.onosproject.net.flow.criteria
-
Implementation of arp_eth_src address or arp_eth_dst address criterion.
- arpOp() - Method in class org.onosproject.net.flow.criteria.ArpOpCriterion
-
Gets the arp operation type to match.
- ArpOpCriterion - Class in org.onosproject.net.flow.criteria
-
Implementation of arp operation type criterion.
- ArpPacketClassifier - Class in org.onosproject.net.packet.packetfilter
- ArpPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.ArpPacketClassifier
- ArpPaCriterion - Class in org.onosproject.net.flow.criteria
-
Implementation of arp spa or tpa address criterion.
- array - Variable in class org.onosproject.net.config.Config
- array() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
-
Convert to byte array.
- arrayNode() - Method in class org.onosproject.ui.UiMessageHandler
-
Returns a freshly minted array node.
- ArraysAsListSerializer - Class in org.onosproject.store.serializers
-
Kryo Serializer for
Arrays.asList(Object...)
. - ArraysAsListSerializer() - Constructor for class org.onosproject.store.serializers.ArraysAsListSerializer
- as(Class<B>) - Method in class org.onosproject.net.AbstractProjectableModel
- as(Class<B>) - Method in class org.onosproject.net.DefaultDevice
- as(Class<B>) - Method in interface org.onosproject.net.driver.Projectable
-
Returns the specified projection of this entity if such projection is supported.
- as(Class<B>) - Method in interface org.onosproject.net.utils.ForwardingDevice
- asArray() - Method in class org.onlab.util.ImmutableByteSequence
-
Creates a new byte array view of this sequence.
- asAtomicCounter() - Method in interface org.onosproject.store.service.AsyncAtomicCounter
-
Returns a new
AtomicCounter
that is backed by this instance and with a default operation timeout. - asAtomicCounter(long) - Method in interface org.onosproject.store.service.AsyncAtomicCounter
-
Returns a new
AtomicCounter
that is backed by this instance. - asAtomicCounterMap() - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
-
Returns a new
AtomicCounterMap
that is backed by this instance. - asAtomicCounterMap(long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
-
Returns a new
AtomicCounterMap
that is backed by this instance. - asAtomicIdGenerator() - Method in interface org.onosproject.store.service.AsyncAtomicIdGenerator
-
Returns a new
AtomicIdGenerator
that is backed by this instance and with a default operation timeout. - asAtomicIdGenerator(long) - Method in interface org.onosproject.store.service.AsyncAtomicIdGenerator
-
Returns a new
AtomicIdGenerator
that is backed by this instance. - asAtomicValue() - Method in interface org.onosproject.store.service.AsyncAtomicValue
-
Returns a new
AtomicValue
that is backed by this instance and with a default operation timeout. - asAtomicValue(long) - Method in interface org.onosproject.store.service.AsyncAtomicValue
-
Returns a new
AtomicValue
that is backed by this instance. - asBatchOperation(DeviceId) - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchRequest
-
Deprecated.
- asBoolean() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as a boolean.
- asByte() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as a byte.
- ASC - org.onosproject.ui.table.TableModel.SortDir
-
Designates an ascending sort.
- asCommunityName() - Method in class org.onosproject.net.key.DeviceKey
-
Returns a community name object from the device key.
- asConsistentMap() - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Returns a new
ConsistentMap
that is backed by this instance. - asConsistentMap(long) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Returns a new
ConsistentMap
that is backed by this instance. - asData() - Method in class org.onosproject.net.AbstractProjectableModel
-
Returns self as an immutable driver data instance.
- asData() - Method in class org.onosproject.net.DefaultDevice
-
Returns self as an immutable driver data instance.
- asDescription() - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
-
Returns equivalent of this Config as
ProtectedTransportEndpointDescription
. - asDistributedSet() - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Returns a new
DistributedSet
that is backed by this instance. - asDistributedSet(long) - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Returns a new
DistributedSet
that is backed by this instance. - asDocumentTree() - Method in interface org.onosproject.store.service.AsyncDocumentTree
-
Returns a new
DocumentTree
that is backed by this instance. - asDocumentTree(long) - Method in interface org.onosproject.store.service.AsyncDocumentTree
-
Returns a new
DocumentTree
that is backed by this instance. - asDouble() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as a double.
- asFloat() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as a float.
- asGHz() - Method in class org.onlab.util.Frequency
-
Return the value this instance represents as GHz.
- asHz() - Method in class org.onlab.util.Frequency
-
Return the value this instance represents as Hz.
- asId() - Method in class org.onosproject.net.LinkKey
-
Returns a string suitable to be used as an identifier.
- asInt() - Method in class org.onosproject.cluster.PartitionId
-
Returns the partition identifier as an integer.
- asInteger() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as an integer.
- asJavaMap() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- asJavaMap() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- asJavaMap() - Method in interface org.onosproject.store.service.ConsistentMap
-
Returns a java.util.Map instance backed by this ConsistentMap.
- asKHz() - Method in class org.onlab.util.Frequency
-
Return the value this instance represents as KHz.
- asLeaderElector() - Method in interface org.onosproject.store.service.AsyncLeaderElector
-
Returns a new
LeaderElector
that is backed by this instance and with a default operation timeout. - asLeaderElector(long) - Method in interface org.onosproject.store.service.AsyncLeaderElector
-
Returns a new
LeaderElector
that is backed by this instance. - asLock() - Method in interface org.onosproject.store.service.AsyncDistributedLock
- asLock(long) - Method in interface org.onosproject.store.service.AsyncDistributedLock
- asLong() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as a long.
- asMap() - Method in class org.onosproject.net.DefaultAnnotations
-
Returns the annotations as a map.
- asMap() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
- asMap() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Returns a map of keys to collections of values that reflect the set of key-value pairs contained in the multimap, where the key value pairs would be the key paired with each of the values in the collection.
- asMap() - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Returns a map of keys to collections of values that reflect the set of key-value pairs contained in the multimap, where the key value pairs would be the key paired with each of the values in the collection.
- asMHz() - Method in class org.onlab.util.Frequency
-
Return the value this instance represents as MHz.
- asMultimap() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Returns a
ConsistentMultimap
instance that wraps this map. - asMultimap(long) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Returns a
ConsistentMultimap
instance that wraps this map. - asReadOnlyBuffer() - Method in class org.onlab.util.ImmutableByteSequence
-
Returns a view of this sequence as a read-only
ByteBuffer
. - assertAfter(int, int, Runnable) - Static method in class org.onlab.junit.TestTools
-
Runs the specified runnable until it completes successfully or until the specified time expires.
- assertAfter(int, Runnable) - Static method in class org.onlab.junit.TestTools
-
Runs the specified runnable until it completes successfully or until the specified time expires.
- assertThatClassIsImmutable(Class<?>) - Static method in class org.onlab.junit.ImmutableClassChecker
-
Assert that the given class adheres to the immutable class rules.
- assertThatClassIsImmutableBaseClass(Class<?>) - Static method in class org.onlab.junit.ImmutableClassChecker
-
Assert that the given class adheres to the immutable class rules, but is not declared final.
- assertThatClassIsUtility(Class<?>) - Static method in class org.onlab.junit.UtilityClassChecker
-
Assert that the given class adheres to the utility class rules.
- assign(IntentData, Timestamp, NodeId) - Static method in class org.onosproject.net.intent.IntentData
-
Creates updated IntentData after assigning task to a node.
- assignedUser() - Method in interface org.onosproject.alarm.Alarm
-
Returns the user to whom this alarm is assigned; this is for future use and always returns null in this release.
- assignedUser() - Method in class org.onosproject.alarm.DefaultAlarm
- assignIP(HostId, IpAssignment) - Method in interface org.onosproject.dhcp.DhcpStore
-
Assigns the requested IP to the Mac ID, in response to a DHCP REQUEST message.
- assignmentStatus() - Method in class org.onosproject.dhcp.IpAssignment
-
Returns the assignment status of the IP assignment.
- assignmentStatus(IpAssignment.AssignmentStatus) - Method in class org.onosproject.dhcp.IpAssignment.Builder
- assignStaticIP(MacAddress, IpAssignment) - Method in interface org.onosproject.dhcp.DhcpStore
-
Assigns the requested IP to the MAC ID (if available) for an indefinite period of time.
- asString() - Method in class org.onosproject.cfg.ConfigProperty
-
Returns the property value as a string.
- asTHz() - Method in class org.onlab.util.Frequency
-
Return the value this instance represents as THz.
- asTreeMap() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
- asTreeMap(long) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
- asUsernamePassword() - Method in class org.onosproject.net.key.DeviceKey
-
Returns a username and password object from the device key.
- AsymmetricPathConstraint - Class in org.onosproject.net.intent.constraint
-
Constraint that serves as a request for asymmetric bi-directional path.
- AsymmetricPathConstraint() - Constructor for class org.onosproject.net.intent.constraint.AsymmetricPathConstraint
- AsyncAtomicCounter - Interface in org.onosproject.store.service
-
An async atomic counter dispenses monotonically increasing values.
- AsyncAtomicCounterMap<K> - Interface in org.onosproject.store.service
-
An async atomic counter map dispenses monotonically increasing values associated with key.
- AsyncAtomicIdGenerator - Interface in org.onosproject.store.service
-
An async ID generator for generating globally unique numbers.
- AsyncAtomicValue<V> - Interface in org.onosproject.store.service
-
Distributed version of java.util.concurrent.atomic.AtomicReference.
- AsyncConsistentMap<K,V> - Interface in org.onosproject.store.service
-
A distributed, strongly consistent map whose methods are all executed asynchronously.
- AsyncConsistentMultimap<K,V> - Interface in org.onosproject.store.service
-
Interface for a distributed multimap.
- AsyncConsistentTreeMap<V> - Interface in org.onosproject.store.service
-
API for a distributed tree map implementation.
- AsyncDeviceFetcher - Class in org.onosproject.routing
-
Provides a means of asynchronously waiting on devices.
- AsyncDistributedLock - Interface in org.onosproject.store.service
-
Asynchronous lock primitive.
- AsyncDistributedSet<E> - Interface in org.onosproject.store.service
-
A distributed collection designed for holding unique elements.
- AsyncDocumentTree<V> - Interface in org.onosproject.store.service
-
A hierarchical document tree data structure.
- AsyncIterable<T> - Interface in org.onosproject.store.service
-
Asynchronously iterable object.
- AsyncIterator<T> - Interface in org.onosproject.store.service
-
Asynchronous iterator.
- AsyncLeaderElector - Interface in org.onosproject.store.service
-
Distributed mutual exclusion primitive.
- AtomicCounter - Interface in org.onosproject.store.service
-
Distributed version of java.util.concurrent.atomic.AtomicLong.
- atomicCounterBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new AtomicCounterBuilder.
- atomicCounterBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new AtomicCounterBuilder.
- AtomicCounterBuilder - Class in org.onosproject.store.service
-
Builder for AtomicCounter.
- AtomicCounterBuilder() - Constructor for class org.onosproject.store.service.AtomicCounterBuilder
- AtomicCounterMap<K> - Interface in org.onosproject.store.service
-
Distributed version of com.google.common.util.concurrent.AtomicLongMap.
- atomicCounterMapBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new
AtomicCounterMapBuilder
. - atomicCounterMapBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new
AtomicCounterMapBuilder
. - AtomicCounterMapBuilder<K> - Class in org.onosproject.store.service
-
Builder for AtomicCounterMap.
- AtomicCounterMapBuilder() - Constructor for class org.onosproject.store.service.AtomicCounterMapBuilder
- AtomicCounterMapOptions<O extends AtomicCounterMapOptions<O,K>,K> - Class in org.onosproject.store.service
-
Builder for AtomicCounterMap.
- AtomicCounterMapOptions() - Constructor for class org.onosproject.store.service.AtomicCounterMapOptions
- AtomicCounterOptions<O extends AtomicCounterOptions<O>> - Class in org.onosproject.store.service
-
Options for AtomicCounter.
- AtomicCounterOptions() - Constructor for class org.onosproject.store.service.AtomicCounterOptions
- AtomicIdGenerator - Interface in org.onosproject.store.service
-
Generator for globally unique numeric identifiers.
- atomicIdGeneratorBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new AtomicIdGeneratorBuilder.
- atomicIdGeneratorBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new AtomicIdGeneratorBuilder.
- AtomicIdGeneratorBuilder - Class in org.onosproject.store.service
-
Builder for AtomicIdGenerator.
- AtomicIdGeneratorBuilder() - Constructor for class org.onosproject.store.service.AtomicIdGeneratorBuilder
- AtomicIdGeneratorOptions<O extends AtomicIdGeneratorOptions<O>> - Class in org.onosproject.store.service
-
Options for AtomicIdGenerator.
- AtomicIdGeneratorOptions() - Constructor for class org.onosproject.store.service.AtomicIdGeneratorOptions
- AtomicValue<V> - Interface in org.onosproject.store.service
-
Distributed version of java.util.concurrent.atomic.AtomicReference.
- atomicValueBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new AtomicValueBuilder.
- atomicValueBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new AtomicValueBuilder.
- AtomicValueBuilder<V> - Class in org.onosproject.store.service
-
Builder for constructing new AtomicValue instances.
- AtomicValueBuilder() - Constructor for class org.onosproject.store.service.AtomicValueBuilder
- AtomicValueEvent<V> - Class in org.onosproject.store.service
-
Representation of a AtomicValue update notification.
- AtomicValueEvent(String, V, V) - Constructor for class org.onosproject.store.service.AtomicValueEvent
-
Creates a new event object.
- AtomicValueEvent.Type - Enum in org.onosproject.store.service
-
AtomicValueEvent type.
- AtomicValueEventListener<V> - Interface in org.onosproject.store.service
-
Listener to be notified about updates to a AtomicValue.
- AtomicValueOptions<O extends AtomicValueOptions<O,V>,V> - Class in org.onosproject.store.service
-
Builder for constructing new AtomicValue instances.
- AtomicValueOptions() - Constructor for class org.onosproject.store.service.AtomicValueOptions
- attachBackingLink(Link) - Method in class org.onosproject.ui.model.topo.UiDeviceLink
-
Attaches the given backing link to this UI link.
- ATTR_GTC - Static variable in class org.onlab.packet.EAP
- ATTR_IDENTITY - Static variable in class org.onlab.packet.EAP
- ATTR_MD5 - Static variable in class org.onlab.packet.EAP
- ATTR_NAK - Static variable in class org.onlab.packet.EAP
- ATTR_NOTIFICATION - Static variable in class org.onlab.packet.EAP
- ATTR_OTP - Static variable in class org.onlab.packet.EAP
- ATTR_TLS - Static variable in class org.onlab.packet.EAP
- attributes - Variable in class org.onlab.packet.RADIUS
- attributes() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState
-
Returns implementation defined attributes.
- AUDIT_ENABLED - Static variable in class org.onosproject.net.OsgiPropertyConstants
- AUDIT_ENABLED_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
- AUDIT_LOGGER - Static variable in class org.onosproject.net.OsgiPropertyConstants
- AUDIT_LOGGER_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
- AuditService - Interface in org.onosproject.security
-
Service for enabling audit logging.
- AUTH - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
- AUTH - org.onlab.packet.DHCP6.OptionCode
- AUTH - org.onosproject.cli.net.ExtHeader
-
Authentication header.
- AUTH - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
-
Authentication header present.
- Authentication - Class in org.onlab.packet.ipv6
-
Implements IPv6 authentication extension header format.
- Authentication() - Constructor for class org.onlab.packet.ipv6.Authentication
- authenticator - Variable in class org.onlab.packet.RADIUS
- authEntry - Variable in class org.onlab.packet.RIP
- authLen - Variable in class org.onlab.packet.RIPV2AuthEntry
- AuthorizationFilter - Class in org.onlab.rest
-
Filter that performs authorization checks on all incoming REST API requests.
- AuthorizationFilter() - Constructor for class org.onlab.rest.AuthorizationFilter
- auxData - Variable in class org.onlab.packet.IGMPMembership
- auxDataLength - Variable in class org.onlab.packet.IGMPMembership
- auxInfo - Variable in class org.onlab.packet.IGMPGroup
- auxLocations() - Method in class org.onosproject.net.config.basics.BasicHostConfig
-
Returns the auxLocations of the host.
- auxLocations() - Method in class org.onosproject.net.DefaultHost
- auxLocations() - Method in interface org.onosproject.net.Host
-
Returns host auxiliary locations, which could be useful for app operations in addition to the attach points.
- auxLocations() - Method in class org.onosproject.net.host.DefaultHostDescription
- auxLocations() - Method in interface org.onosproject.net.host.HostDescription
-
Returns host auxiliary locations, which could be useful for app operations in addition to the attach points.
- AVAILABLE - org.onosproject.store.primitives.PartitionEvent.Type
-
Signifies that a partition is available for operations.
- availableResources(NodeId, ControlResource.Type) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
-
Obtains a list of names of available resources.
- availableResourcesSync(NodeId, ControlResource.Type) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
-
Synchronous version of availableResource.
- average() - Method in interface org.onosproject.cpman.ControlLoad
-
Obtains the average of all time duration.
- average() - Method in class org.onosproject.cpman.ControlLoadSnapshot
-
Returns average value of control metric.
- average(int, TimeUnit) - Method in interface org.onosproject.cpman.ControlLoad
-
Obtains the average of the specified time duration.
- averageNanos() - Method in interface org.onosproject.net.packet.PacketProcessorEntry
-
Returns the average time, in nanoseconds, spent processing packets.
- await(boolean) - Method in class org.onlab.util.BlockingBoolean
-
Causes the current thread to wait until the boolean equals the specified value unless the thread is interrupted.
- await(boolean, long, TimeUnit) - Method in class org.onlab.util.BlockingBoolean
-
Causes the current thread to wait until the boolean equals the specified value unless the thread is interrupted, or the specified waiting time elapses.
- awaitTermination(long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
- awaitTermination(long, TimeUnit) - Method in class org.onlab.util.PredictableExecutor
- awaitTermination(long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
B
- B_PER_SEC - org.onosproject.net.behaviour.trafficcontrol.Policer.Unit
-
Byte per second.
- B_TO_A - org.onosproject.ui.model.topo.UiLinkId.Direction
- BACK_EDGE - org.onlab.graph.DepthFirstSearch.EdgeType
- backendExecutorService(ThreadFactory, boolean) - Method in class org.onlab.util.PredictableExecutor
-
Creates a single thread
ExecutorService
to use in the backend. - backingDevice() - Method in class org.onosproject.ui.model.topo.UiDevice
-
Returns the device instance backing this UI device.
- backingHost() - Method in class org.onosproject.ui.model.topo.UiHost
-
Returns the host instance backing this UI host.
- backingNode() - Method in class org.onosproject.ui.model.topo.UiClusterMember
-
Returns the controller node instance backing this UI cluster member.
- backingRegion() - Method in class org.onosproject.ui.model.topo.UiRegion
-
Returns the region instance backing this UI region.
- Backtrace - Exception in org.onlab.util
-
RuntimeException object intended to used to log execution back trace.
- Backtrace() - Constructor for exception org.onlab.util.Backtrace
- backup() - Method in class org.onosproject.net.DefaultDisjointPath
- backup() - Method in interface org.onosproject.net.DisjointPath
-
Gets secondary path.
- BACKUP - org.onosproject.net.intent.PathIntent.ProtectionType
-
Intent within backup path.
- BACKUP_PERIOD_MILLIS - Static variable in class org.onosproject.store.OsgiPropertyConstants
- BACKUP_PERIOD_MILLIS_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
- backups() - Method in class org.onosproject.cluster.RoleInfo
- backups() - Method in class org.onosproject.mastership.MastershipInfo
-
Returns a sorted list of standby nodes.
- backups() - Method in class org.onosproject.store.flow.ReplicaInfo
-
Returns the collection of NodeId, where backup copies should be placed.
- BACKUPS_CHANGED - org.onosproject.mastership.MastershipEvent.Type
-
Signifies that the list of backup nodes has changed.
- BACKUPS_CHANGED - org.onosproject.store.flow.ReplicaInfoEvent.Type
- BAD_BAND - org.onosproject.net.meter.MeterFailReason
-
Bad band.
- BAD_BAND_VALUE - org.onosproject.net.meter.MeterFailReason
-
Bad value value.
- BAD_BUCKET - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
- BAD_BURST - org.onosproject.net.meter.MeterFailReason
-
Bad burst size value.
- BAD_COMMAND - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
- BAD_RATE - org.onosproject.net.meter.MeterFailReason
-
Bad rate value.
- BAD_TYPE - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
- BAD_WATCH - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
- badge() - Method in class org.onosproject.ui.topo.NodeHighlight
-
Returns the badge for this node, if any.
- BADPARAMS - org.onosproject.net.flowobjective.ObjectiveError
-
Incorrect Objective parameters passed in by the caller.
- BadRequestMapper - Class in org.onlab.rest.exceptions
-
Mapper for IO exceptions to the BAD_REQUEST response code.
- BadRequestMapper() - Constructor for class org.onlab.rest.exceptions.BadRequestMapper
- BalanceMastersCommand - Class in org.onosproject.cli
-
Forces device mastership rebalancing.
- BalanceMastersCommand() - Constructor for class org.onosproject.cli.BalanceMastersCommand
- BALANCER - org.onosproject.net.Device.Type
- balanceRoles() - Method in interface org.onosproject.mastership.MastershipAdminService
-
Balances the mastership to be shared as evenly as possibly by all online instances.
- Band - Interface in org.onosproject.net.meter
-
Represents a band used within a meter.
- Band.Builder - Interface in org.onosproject.net.meter
- Band.Type - Enum in org.onosproject.net.meter
-
Specifies the type of band.
- BandEntry - Interface in org.onosproject.net.meter
-
Represents a stored band.
- bands() - Method in class org.onosproject.net.meter.DefaultMeter
- bands() - Method in class org.onosproject.net.meter.DefaultMeterRequest
- bands() - Method in interface org.onosproject.net.meter.Meter
-
The collection of bands to apply on the dataplane.
- bands() - Method in interface org.onosproject.net.meter.MeterRequest
-
The collection of bands to apply on the dataplane.
- bandTypes() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
- bandTypes() - Method in interface org.onosproject.net.meter.MeterFeatures
-
Returns band types supported.
- bandwidth() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
-
Returns link bandwidth in terms of Mbps.
- bandwidth() - Method in class org.onosproject.net.intent.constraint.BandwidthConstraint
-
Returns the bandwidth required by this constraint.
- bandwidth(Long) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
-
Sets the link bandwidth.
- Bandwidth - Interface in org.onlab.util
-
Representation of bandwidth.
- BANDWIDTH - Static variable in class org.onosproject.net.AnnotationKeys
-
Annotation key for bandwidth.
- BANDWIDTH - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
- BandwidthCapacity - Class in org.onosproject.net.config.basics
-
Configuration to specify maximum available bandwidth resource (Capacity) on a port.
- BandwidthCapacity() - Constructor for class org.onosproject.net.config.basics.BandwidthCapacity
- BandwidthConstraint - Class in org.onosproject.net.intent.constraint
-
Constraint that evaluates links based on available bandwidths.
- BandwidthConstraint(Bandwidth) - Constructor for class org.onosproject.net.intent.constraint.BandwidthConstraint
-
Creates a new bandwidth constraint.
- BandwidthProfile - Class in org.onosproject.net.behaviour
-
Implementation of a generic bandwidth profile (marker/policer).
- BandwidthProfile.Builder - Class in org.onosproject.net.behaviour
-
Builder of BandwidthProfile entities.
- BandwidthProfileAction - Class in org.onosproject.net.behaviour
-
Represents an action to be taken by a marker/policer.
- BandwidthProfileAction.Action - Enum in org.onosproject.net.behaviour
-
Denotes the type of action to be taken.
- BandwidthProfileAction.Builder - Class in org.onosproject.net.behaviour
-
Builder of BandwidthProfileAction entities.
- BandwidthProfileConfigBehaviour - Interface in org.onosproject.net.behaviour
-
Means to configure bandwidth profiles on devices.
- BaseConfig<S> - Class in org.onosproject.net.config
-
Config
with access toCodecService
. - BaseConfig() - Constructor for class org.onosproject.net.config.BaseConfig
- BaseLink - Class in org.onosproject.ui.topo
-
A simple concrete implementation of a
BiLink
. - BaseLink(LinkKey, Link) - Constructor for class org.onosproject.ui.topo.BaseLink
-
Constructs a base link for the given key and initial link.
- BaseLinkMap - Class in org.onosproject.ui.topo
-
Collection of
BaseLink
s. - BaseLinkMap() - Constructor for class org.onosproject.ui.topo.BaseLinkMap
- BaseOptions - Class in org.onlab.packet.ipv6
-
Base class for hop-by-hop options and destination options.
- BaseOptions() - Constructor for class org.onlab.packet.ipv6.BaseOptions
- BasePacket - Class in org.onlab.packet
-
Base packet class.
- BasePacket() - Constructor for class org.onlab.packet.BasePacket
- BaseResource - Class in org.onlab.rest
-
Base abstraction of a JAX-RS resource.
- BaseResource() - Constructor for class org.onlab.rest.BaseResource
- BASIC - Static variable in class org.onosproject.store.serializers.KryoNamespaces
-
WARNING: Do not change ordering of registrations! Serial IDs are automatically assigned to types registered via the
KryoNamespace
API. - BASIC_MAX_SIZE - Static variable in class org.onosproject.store.serializers.KryoNamespaces
- BasicDeviceConfig - Class in org.onosproject.net.config.basics
-
Basic configuration for network infrastructure devices.
- BasicDeviceConfig() - Constructor for class org.onosproject.net.config.basics.BasicDeviceConfig
- BasicElementConfig<S> - Class in org.onosproject.net.config.basics
-
Basic configuration for network elements, e.g.
- BasicElementConfig() - Constructor for class org.onosproject.net.config.basics.BasicElementConfig
- BasicFeatureConfig<S> - Class in org.onosproject.net.config.basics
-
Base abstraction for configuring feature on subject.
- BasicFeatureConfig(boolean) - Constructor for class org.onosproject.net.config.basics.BasicFeatureConfig
- BasicHostConfig - Class in org.onosproject.net.config.basics
-
Basic configuration for network end-station hosts.
- BasicHostConfig() - Constructor for class org.onosproject.net.config.basics.BasicHostConfig
- BasicLinkConfig - Class in org.onosproject.net.config.basics
-
Basic configuration for network infrastructure link.
- BasicLinkConfig() - Constructor for class org.onosproject.net.config.basics.BasicLinkConfig
-
Create a
BasicLinkConfig
instance. - BasicLinkConfig(LinkKey) - Constructor for class org.onosproject.net.config.basics.BasicLinkConfig
-
Create a
BasicLinkConfig
for specified Device. - BasicNetworkConfigService - Interface in org.onosproject.net.config
-
Service representing the availability of the basic network configs.
- BasicRegionConfig - Class in org.onosproject.net.config.basics
-
Basic configuration for network regions.
- BasicRegionConfig() - Constructor for class org.onosproject.net.config.basics.BasicRegionConfig
- BasicSystemOperations - Interface in org.onosproject.net.behaviour
-
Handler behaviour capable of device reboot execution and getting system time since UNIX epoch.
- BasicUiTopoLayoutConfig - Class in org.onosproject.net.config.basics
-
Basic configuration for UI topology layouts.
- BasicUiTopoLayoutConfig() - Constructor for class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
- BATCH_OPERATION_COMPLETED - org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent.Type
-
Deprecated.Signifies that a batch operation has completed.
- BATCH_OPERATION_REQUESTED - org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent.Type
-
Deprecated.Signifies that a batch operation has been initiated.
- batchId() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchRequest
-
Deprecated.
- BatchOperation<T extends BatchOperationEntry<?,?>> - Class in org.onosproject.net.flow
-
A list of BatchOperationEntry.
- BatchOperation() - Constructor for class org.onosproject.net.flow.BatchOperation
-
Creates new
BatchOperation
object. - BatchOperation(Collection<T>) - Constructor for class org.onosproject.net.flow.BatchOperation
-
Creates
BatchOperation
object from a list of batch operation entries. - batchOperationComplete(FlowRuleBatchEvent) - Method in interface org.onosproject.net.flow.FlowRuleStore
-
Invoked on the completion of a storeBatch operation.
- batchOperationCompleted(long, CompletedBatchOperation) - Method in interface org.onosproject.net.flow.FlowRuleProviderService
-
Indicates to the core that the requested batch operation has been completed.
- BatchOperationEntry<T extends java.lang.Enum<?>,U> - Class in org.onosproject.net.flow
-
A super class for batch operation entry classes.
- BatchOperationEntry(T, U) - Constructor for class org.onosproject.net.flow.BatchOperationEntry
-
Constructs new instance for the entry of the BatchOperation.
- BatchOperationResult<T> - Interface in org.onosproject.net.flow
-
Interface capturing the result of a batch operation.
- batchWrite(Iterable<IntentData>) - Method in interface org.onosproject.net.intent.IntentStore
-
Writes a batch of IntentData objects to the store.
- BDDP - org.onlab.packet.EthType.EtherType
- BE - org.onlab.packet.DscpClass
- beforeExecute(Thread, Runnable) - Method in class org.onlab.util.BoundedThreadPool
- begin() - Method in interface org.onosproject.store.service.TransactionContext
-
Starts a new transaction.
- begin(TransactionId) - Method in interface org.onosproject.store.service.Transactional
-
Begins the transaction.
- BEGIN_USER_CUSTOM_ID - Static variable in class org.onosproject.store.serializers.KryoNamespaces
-
Kryo registration Id for user custom registration.
- behaviour(Class<T>) - Method in class org.onosproject.net.driver.DefaultDriverHandler
- behaviour(Class<T>) - Method in interface org.onosproject.net.driver.DriverData
-
Returns the specified facet of behaviour to access the device data.
- behaviour(Class<T>) - Method in interface org.onosproject.net.driver.DriverHandler
-
Returns the specified facet of behaviour to interact with the device.
- Behaviour - Interface in org.onosproject.net.driver
-
Representation of a facet of behaviour that can be used to talk about an entity (in context of
DriverData
) or to an entity (in context ofDriverHandler
). - BehaviourClassResolver - Interface in org.onosproject.net.driver
-
Entity capable of resolving a class using its name.
- behaviours() - Method in class org.onosproject.net.driver.DefaultDriver
- behaviours() - Method in interface org.onosproject.net.driver.Driver
-
Returns the set of behaviours supported by this driver.
- behaviours() - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
- behaviours() - Method in interface org.onosproject.net.pi.model.PiPipeconf
-
Returns all pipeline-specific behaviour interfaces defined by this configuration.
- BellmanFordGraphSearch<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Bellman-Ford graph search algorithm for locating shortest-paths in directed graphs that may contain negative cycles.
- BellmanFordGraphSearch() - Constructor for class org.onlab.graph.BellmanFordGraphSearch
- BEST_EFFORT - org.onlab.packet.IPPrecedence
- BEYOND_SCOPE - org.onosproject.cli.net.Icmp6Code
-
Beyond scope of source address.
- BEYOND_SCOPE - Static variable in class org.onlab.packet.ICMP6
-
Beyond scope of source address.
- BGP_SPEAKER - Static variable in class org.onosproject.ui.GlyphConstants
- BgpConfig - Class in org.onosproject.routing.config
-
Configuration object for BGP config.
- BgpConfig() - Constructor for class org.onosproject.routing.config.BgpConfig
- BgpConfig.BgpSpeakerConfig - Class in org.onosproject.routing.config
-
Configuration for a BGP speaker.
- BgpSpeakerConfig(Optional<String>, VlanId, ConnectPoint, Set<IpAddress>) - Constructor for class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
- bgpSpeakers() - Method in class org.onosproject.routing.config.BgpConfig
-
Gets the set of configured BGP speakers.
- bidirectional(boolean) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
-
Sets the directionality of the intent.
- bidirectional(boolean) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
-
Sets the directionality of the intent.
- bidirectional(boolean) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
-
Sets the directionality of the intent.
- bidirectional(boolean) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
-
Sets the intent's direction.
- BiLink - Class in org.onosproject.ui.topo
-
Representation of a link and its inverse, as a partial implementation.
- BiLink(LinkKey, Link) - Constructor for class org.onosproject.ui.topo.BiLink
-
Constructs a bi-link for the given key and initial link.
- BiLink(UiLinkId) - Constructor for class org.onosproject.ui.topo.BiLink
-
Constructs a bi-link for the given UI link identifier; sets remaining fields to null.
- BiLinkMap<B extends BiLink> - Class in org.onosproject.ui.topo
-
Represents a collection of
BiLink
concrete classes. - BiLinkMap() - Constructor for class org.onosproject.ui.topo.BiLinkMap
- biLinks() - Method in class org.onosproject.ui.topo.BiLinkMap
-
Returns the bi-link instances in the collection.
- bindAndCheckDriver() - Method in class org.onosproject.net.AbstractProjectableModel
-
Attempts to bind the driver, if not already bound and checks that the driver is bound.
- bindDriver() - Method in class org.onosproject.net.AbstractProjectableModel
-
Attempts to binds the driver, if not already bound.
- bindIdGenerator(IdGenerator) - Static method in class org.onosproject.net.intent.Intent
-
Binds an id generator for unique intent id generation.
- bindService(NetworkConfigService) - Method in interface org.onosproject.net.config.DeviceConfigOperator
-
Binds
NetworkConfigService
to use for retrieving configuration. - bindService(NetworkConfigService) - Method in interface org.onosproject.net.config.HostConfigOperator
-
Binds
NetworkConfigService
to use for retrieving configuration. - bindService(NetworkConfigService) - Method in interface org.onosproject.net.config.PortConfigOperator
-
Binds
NetworkConfigService
to use for retrieving configuration. - bindToDevice(PiPipeconfId, DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
-
Signals that the given pipeconf is associated to the given infrastructure device.
- BIRD - Static variable in class org.onosproject.ui.GlyphConstants
- BIT_LENGTH - Static variable in class org.onlab.packet.Ip4Address
- BIT_LENGTH - Static variable in class org.onlab.packet.Ip6Address
- bitRate() - Method in enum org.onosproject.net.CltSignalType
-
Return the bit rate in Mbps of the port.
- bitRate() - Method in enum org.onosproject.net.OduSignalType
-
Return the bit rate in Mbps of the port.
- BITS_UNIT - Static variable in class org.onosproject.ui.topo.TopoUtils
- BitSetSerializer - Class in org.onosproject.store.serializers
-
Kryo serializer for
BitSet
. - BitSetSerializer() - Constructor for class org.onosproject.store.serializers.BitSetSerializer
-
Creates
BitSet
serializer instance. - bitString() - Method in class org.onosproject.net.pi.runtime.data.PiBitString
-
Return protocol-independent bitString instance.
- BITSTRING - org.onosproject.net.pi.model.PiData.Type
-
Bit String.
- bitStrings() - Method in class org.onosproject.net.pi.runtime.data.PiHeader
-
Return the header bit strings.
- bitWidth() - Method in interface org.onosproject.net.pi.model.PiActionParamModel
-
Return the size in bits of this action parameter.
- bitWidth() - Method in interface org.onosproject.net.pi.model.PiMatchFieldModel
-
Returns the number of bits matched by this field.
- bitWidth() - Method in interface org.onosproject.net.pi.model.PiPacketMetadataModel
-
Returns the size in bits of this metadata.
- bitwiseAnd(ImmutableByteSequence) - Method in class org.onlab.util.ImmutableByteSequence
-
Returns a new byte sequence corresponding to the result of a bitwise AND operation between this sequence and the given other, i.e.
- bitwiseOr(ImmutableByteSequence) - Method in class org.onlab.util.ImmutableByteSequence
-
Returns a new byte sequence corresponding to the result of a bitwise OR operation between this sequence and the given other, i.e.
- bitwiseXor(ImmutableByteSequence) - Method in class org.onlab.util.ImmutableByteSequence
-
Returns a new byte sequence corresponding to the result of a bitwise XOR operation between this sequence and the given other, i.e.
- block() - Method in class org.onosproject.net.packet.DefaultPacketContext
- block() - Method in interface org.onosproject.net.packet.PacketContext
-
Blocks the outbound packet from being sent from this point onward.
- BLOCK_OLD_SOURCES - Static variable in class org.onlab.packet.IGMPMembership
- BlockingAwareFuture<T> - Class in org.onlab.util
-
A
CompletableFuture
that tracks whether the future or one of its descendants has been blocked on aCompletableFuture.get()
orCompletableFuture.join()
call. - BlockingAwareFuture() - Constructor for class org.onlab.util.BlockingAwareFuture
- BlockingBoolean - Class in org.onlab.util
-
Mutable boolean that allows threads to wait for a specified value.
- BlockingBoolean(boolean) - Constructor for class org.onlab.util.BlockingBoolean
-
Creates a new blocking boolean with the specified value.
- BMV2_JSON - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
-
BMv2 JSON configuration.
- BngProgrammable - Interface in org.onosproject.net.behaviour
-
BNG programmable behavior.
- BngProgrammable.Attachment - Interface in org.onosproject.net.behaviour
-
Immutable representation of an attachment in the BNG context.
- BngProgrammable.Attachment.AttachmentType - Enum in org.onosproject.net.behaviour
-
Types of attachment.
- BngProgrammable.BngCounterType - Enum in org.onosproject.net.behaviour
-
Counters to implement BNG accounting.
- BngProgrammable.BngProgrammableException - Exception in org.onosproject.net.behaviour
-
An exception indicating a an error happened in the BNG programmable behaviour.
- BngProgrammableException(String) - Constructor for exception org.onosproject.net.behaviour.BngProgrammable.BngProgrammableException
-
Creates a new exception for the given message.
- BODY_LENGTH_MSB_MASK - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
- BODY_LENGTH_MSB_SHIFT - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
- BODY_LENGTH_OCTET_OFFSET - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
- bool() - Method in class org.onosproject.net.pi.runtime.data.PiBool
-
Return protocol-independent Boolean instance.
- bool(ObjectNode, String) - Static method in class org.onosproject.ui.JsonUtils
-
Returns the specified node property as a boolean.
- bool(ObjectNode, String) - Method in class org.onosproject.ui.RequestHandler
-
Returns the specified node property as a boolean.
- BOOL - org.onosproject.net.pi.model.PiData.Type
-
Bool.
- BOOLEAN - org.onosproject.cfg.ConfigProperty.Type
-
Indicates the value is a boolean.
- BooleanConstraint - Class in org.onosproject.net.intent.constraint
-
Abstract base class for various constraints that evaluate link viability in a yes/no fashion.
- BooleanConstraint() - Constructor for class org.onosproject.net.intent.constraint.BooleanConstraint
- bootFileName - Variable in class org.onlab.packet.DHCP
- borrow() - Method in class org.onlab.util.KryoNamespace
- bos - Variable in class org.onlab.packet.MPLS
- BoundedThreadPool - Class in org.onlab.util
-
Implementation of ThreadPoolExecutor that bounds the work queue.
- bps() - Method in interface org.onlab.util.Bandwidth
-
Returns bandwidth in bps.
- bps(double) - Static method in interface org.onlab.util.Bandwidth
-
Creates a new instance with given bandwidth in bps.
- bps(long) - Static method in interface org.onlab.util.Bandwidth
-
Creates a new instance with given bandwidth in bps.
- BPS - org.onlab.util.DataRateUnit
-
Bit per second.
- BPS_FIXED_PART_SIZE_UPTO_LENGTH_FIELD - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
- BPS_FIXED_PART_TOTAL_SIZE - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
- BreadthFirstSearch<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Implementation of the BFS algorithm.
- BreadthFirstSearch() - Constructor for class org.onlab.graph.BreadthFirstSearch
- BridgeConfig - Interface in org.onosproject.net.behaviour
-
Behaviour for handling various drivers for bridge configurations.
- BridgeDescription - Interface in org.onosproject.net.behaviour
-
The abstraction of a bridge.
- BridgeDescription.Builder - Interface in org.onosproject.net.behaviour
-
/** Builder of bridge description entities.
- BridgeDescription.FailMode - Enum in org.onosproject.net.behaviour
- bridgeName(String) - Static method in class org.onosproject.net.behaviour.BridgeName
-
Creates a bridge name using the supplied string.
- BridgeName - Class in org.onosproject.net.behaviour
-
Represents for a bridge name.
- broadcast() - Method in class org.onosproject.dhcp.IpAssignment
-
Returns broadcast address of the IP assignment.
- broadcast(M, MessageSubject, Function<M, byte[]>) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
-
Broadcasts a message to all controller nodes.
- broadcast(Ip4Address) - Method in class org.onosproject.dhcp.IpAssignment.Builder
- BROADCAST - org.onosproject.net.flowobjective.NextObjective.Type
-
Broadcast packet process.
- BROADCAST - Static variable in class org.onlab.packet.MacAddress
-
Broadcast MAC address.
- broadcastAddress() - Method in class org.onosproject.net.host.InterfaceIpAddress
-
Gets the subnet IP broadcast address.
- broadcastIncludeSelf(M, MessageSubject, Function<M, byte[]>) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
-
Broadcasts a message to all controller nodes including self.
- broadcastPoints(ClusterId) - Method in class org.onosproject.common.DefaultTopology
-
Returns the set of the cluster broadcast points.
- broadcastSetSize(ClusterId) - Method in class org.onosproject.common.DefaultTopology
-
Returns the size of the cluster broadcast set.
- BSN - org.onosproject.cli.net.EthType
-
BSN.
- buckets() - Method in class org.onosproject.net.group.DefaultGroupDescription
-
Returns group buckets of a group.
- buckets() - Method in class org.onosproject.net.group.GroupBuckets
-
Returns immutable list of group buckets.
- buckets() - Method in interface org.onosproject.net.group.GroupDescription
-
Returns group buckets of a group.
- buckets() - Method in class org.onosproject.net.group.GroupOperation
-
Returns group buckets associated with the operation.
- build() - Method in class org.onlab.graph.TarjanGraphSearch.SccResult
- build() - Method in class org.onlab.util.KryoNamespace.Builder
-
Builds a
KryoNamespace
instance. - build() - Method in class org.onosproject.alarm.DefaultAlarm.Builder
-
Builds the alarm.
- build() - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
-
Builds a default application object from the gathered parameters.
- build() - Method in class org.onosproject.core.DefaultApplication.Builder
-
Builds a default application object from the gathered parameters.
- build() - Method in class org.onosproject.core.Version
-
Returns the version build string.
- build() - Method in interface org.onosproject.cpman.MetricsDatabase.Builder
-
Builds a metric database instance.
- build() - Method in interface org.onosproject.cpman.SystemInfo.Builder
-
Builds a SystemInfo object.
- build() - Method in class org.onosproject.dhcp.IpAssignment.Builder
- build() - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
-
Builds a new BandwidthProfile instance.
- build() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction.Builder
-
Builds a new BandwidthProfileAction based on builder's parameters.
- build() - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
-
Builds an immutable bridge description.
- build() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
- build() - Method in class org.onosproject.net.behaviour.DefaultPatchDescription.Builder
- build() - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
- build() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
- build() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
- build() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
-
Builds the IntConfig object.
- build() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective.Builder
-
Builds the IntObjective.
- build() - Method in interface org.onosproject.net.behaviour.PatchDescription.Builder
-
Returns new patch interface description.
- build() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState.Builder
-
Builds
ProtectedTransportEndpointState
. - build() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription.Builder
-
Builds
TransportEndpointDescription
. - build() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
-
Builds
TransportEndpointState
. - build() - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
-
Builds an immutable qos description.
- build() - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
-
Builds an immutable bridge description.
- build() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
- build() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
- build() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
-
Builds the policer based on the specified parameters when possible.
- build() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Builder
-
Builds the token bucket based on the specified parameters when possible.
- build() - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
-
Returns new tunnel interface description.
- build() - Method in class org.onosproject.net.DefaultAnnotations.Builder
-
Returns immutable annotations built from the accrued key/values pairs.
- build() - Method in class org.onosproject.net.DefaultLink.Builder
-
Builds a default link object from the accumulated parameters.
- build() - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
-
Builds the port description.
- build() - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
-
Creates a PortStatistics object.
- build() - Method in class org.onosproject.net.domain.DomainIntentOperations.Builder
-
Builds the immutable domain intent operations.
- build() - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
-
Builds a point to point domain intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
-
Builds a PiCriterion.
- build() - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
- build() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
- build() - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
- build() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- build() - Method in interface org.onosproject.net.flow.FlowRule.Builder
-
Builds a flow rule object.
- build() - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
-
Builds the immutable flow rule operations.
- build() - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
-
Builds an immutable traffic selector.
- build() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Builds an immutable traffic treatment descriptor.
- build() - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
-
Builds a host to host intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
-
Builds a single point to multi point intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
-
Builds a multi point to single point intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
-
Builds an optical circuit intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
-
Builds an optical connectivity intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
-
Builds an optical ODU intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
-
Builds an optical path intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.PathIntent.Builder
-
Builds a path intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
-
Builds a point to point intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
-
Builds a point to point intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
- build() - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
-
Builds a single point to multi point intent from the accumulated parameters.
- build() - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
-
Builds a point to point intent from the accumulated parameters.
- build() - Method in interface org.onosproject.net.meter.Band.Builder
-
Builds the band.
- build() - Method in class org.onosproject.net.meter.DefaultBand.Builder
- build() - Method in class org.onosproject.net.meter.DefaultMeter.Builder
- build() - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
- build() - Method in interface org.onosproject.net.meter.Meter.Builder
-
Builds the meter based on the specified parameters.
- build() - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
-
Builds the Meter Features based on the specified parameters.
- build() - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf.Builder
-
Creates a new pipeconf.
- build() - Method in class org.onosproject.net.pi.runtime.PiAction.Builder
-
Returns a new action instance.
- build() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
-
Creates a new action profile group.
- build() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember.Builder
-
Creates a new action profile member.
- build() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry.Builder
-
Returns a new clone session entry.
- build() - Method in class org.onosproject.net.pi.runtime.PiMatchKey.Builder
-
Creates a new match key.
- build() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig.Builder
-
Builds the meter cell configuration.
- build() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry.Builder
-
Returns a new multicast group entry.
- build() - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata.Builder
-
Returns a new packet metadata instance.
- build() - Method in class org.onosproject.net.pi.runtime.PiPacketOperation.Builder
-
Builds a new instance of a packet operation.
- build() - Method in class org.onosproject.net.pi.runtime.PiRegisterCell.Builder
-
Builds the register cell entry.
- build() - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
-
Builds the table entry.
- build() - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
-
Builds a new pipeline traceable output.
- build() - Method in interface org.onosproject.persistence.PersistentMapBuilder
-
Validates the map settings and then builds this map in the database.
- build() - Method in interface org.onosproject.persistence.PersistentSetBuilder
-
Validates the set settings and then builds this map in the database.
- build() - Method in interface org.onosproject.store.primitives.DistributedPrimitiveBuilder
-
Constructs an instance of the distributed primitive.
- build() - Method in class org.onosproject.store.primitives.MapUpdate.Builder
- build() - Method in class org.onosproject.store.primitives.NodeUpdate.Builder
- build() - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
-
Builds an eventually consistent map based on the configuration options supplied to this builder.
- build() - Method in class org.onosproject.store.service.WorkQueueStats.Builder
- build() - Method in class org.onosproject.ui.lion.LionBundle.Builder
-
Builds the lion bundle from this builder instance.
- build() - Method in class org.onosproject.ui.UiExtension.Builder
-
Builds the user interface extension.
- build(String) - Method in class org.onlab.util.KryoNamespace.Builder
-
Builds a
KryoNamespace
instance. - build(DomainIntentOperationsContext) - Method in class org.onosproject.net.domain.DomainIntentOperations.Builder
-
Builds the immutable domain intent operations.
- build(FlowRuleOperationsContext) - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
-
Builds the immutable flow rule operations.
- buildArpReply(Ip4Address, MacAddress, Ethernet) - Static method in class org.onlab.packet.ARP
-
Builds an ARP reply based on a request.
- buildArpRequest(byte[], byte[], byte[], byte[], byte[], short) - Static method in class org.onlab.packet.ARP
-
Builds an ARP request using the supplied parameters.
- buildArpRequest(byte[], byte[], byte[], short) - Static method in class org.onlab.packet.ARP
-
Builds an ARP request using the supplied parameters.
- buildAsyncMap() - Method in class org.onosproject.store.service.AtomicCounterMapBuilder
-
Builds an async atomic counter map based on the configuration options supplied to this builder.
- buildAsyncMap() - Method in class org.onosproject.store.service.ConsistentMapBuilder
-
Builds an async consistent map based on the configuration options supplied to this builder.
- buildCompressed() - Method in class org.onosproject.net.DefaultAnnotations.Builder
-
Returns immutable annotations built from the accrued key/values pairs after compressing them to eliminate removed annotation tombstones.
- buildConstraints() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
-
Builds the constraint list for this command based on the command line parameters.
- buildDescription(List<TransportEndpointDescription>, DeviceId, String) - Static method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
-
Creates a
ProtectedTransportEndpointDescription
. - buildDocumentTree() - Method in class org.onosproject.store.service.DocumentTreeBuilder
-
Builds the distributed Document tree based on the configuration options supplied to this builder.
- builder() - Static method in class org.onosproject.app.DefaultApplicationDescription
-
Returns a default application description builder.
- builder() - Static method in class org.onosproject.core.DefaultApplication
-
Returns a default application builder.
- builder() - Static method in class org.onosproject.dhcp.IpAssignment
-
Creates and returns a new builder instance.
- builder() - Static method in class org.onosproject.net.behaviour.BandwidthProfile
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.behaviour.BandwidthProfileAction
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.behaviour.DefaultBridgeDescription
-
Creates and returns a new builder instance.
- builder() - Static method in class org.onosproject.net.behaviour.DefaultPatchDescription
-
Returns new builder instance.
- builder() - Static method in class org.onosproject.net.behaviour.DefaultQosDescription
- builder() - Static method in class org.onosproject.net.behaviour.DefaultQueueDescription
- builder() - Static method in class org.onosproject.net.behaviour.DefaultTunnelDescription
-
Creates and returns a new builder instance.
- builder() - Static method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective
-
Returns a new INT objective builder.
- builder() - Static method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
-
Returns
ProtectedTransportEndpointState
builder. - builder() - Static method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription
-
Returns
TransportEndpointDescription
builder. - builder() - Static method in class org.onosproject.net.behaviour.protection.TransportEndpointState
-
Returns
TransportEndpointState
builder. - builder() - Static method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
-
Returns a new builder reference.
- builder() - Static method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
-
Returns a new builder reference.
- builder() - Static method in class org.onosproject.net.DefaultAnnotations
-
Creates a new annotations builder.
- builder() - Static method in class org.onosproject.net.DefaultLink
-
Creates a new default link builder.
- builder() - Static method in class org.onosproject.net.device.DefaultPortDescription
-
Creates port description builder with default parameters.
- builder() - Static method in class org.onosproject.net.device.DefaultPortStatistics
-
Creates a builder for DefaultPortStatistics object.
- builder() - Static method in class org.onosproject.net.domain.DomainIntentOperations
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.domain.DomainPointToPointIntent
-
Returns a new point to point domain intent builder.
- builder() - Static method in class org.onosproject.net.flow.criteria.PiCriterion
-
Returns the PiCriterion builder.
- builder() - Static method in class org.onosproject.net.flow.DefaultFlowRule
-
Returns a default flow rule builder.
- builder() - Static method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
- builder() - Static method in class org.onosproject.net.flow.DefaultTrafficSelector
-
Returns a new traffic selector builder.
- builder() - Static method in class org.onosproject.net.flow.DefaultTrafficTreatment
-
Returns a new traffic treatment builder.
- builder() - Static method in class org.onosproject.net.flow.FlowRuleOperations
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.flowobjective.DefaultNextObjective
-
Returns a new builder.
- builder() - Static method in class org.onosproject.net.intent.HostToHostIntent
-
Returns a new host to host intent builder.
- builder() - Static method in class org.onosproject.net.intent.LinkCollectionIntent
-
Returns a new link collection intent builder.
- builder() - Static method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
-
Returns a new multi point to single point intent builder.
- builder() - Static method in class org.onosproject.net.intent.OpticalCircuitIntent
-
Returns a new optical circuit intent builder.
- builder() - Static method in class org.onosproject.net.intent.OpticalConnectivityIntent
-
Returns a new optical connectivity intent builder.
- builder() - Static method in class org.onosproject.net.intent.OpticalOduIntent
-
Returns a new optical ODU intent builder.
- builder() - Static method in class org.onosproject.net.intent.OpticalPathIntent
-
Returns a new optical connectivity intent builder.
- builder() - Static method in class org.onosproject.net.intent.PathIntent
-
Returns a new host to host intent builder.
- builder() - Static method in class org.onosproject.net.intent.PointToPointIntent
-
Returns a new point to point intent builder.
- builder() - Static method in class org.onosproject.net.intent.ProtectedTransportIntent
-
Returns a new
ProtectedTransportIntent
builder. - builder() - Static method in class org.onosproject.net.intent.ProtectionEndpointIntent
-
Returns a new
ProtectionEndpointIntent
builder. - builder() - Static method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
-
Returns a new single point to multi point intent builder.
- builder() - Static method in class org.onosproject.net.intent.TwoWayP2PIntent
-
Returns a new two way intent builder.
- builder() - Static method in class org.onosproject.net.meter.DefaultBand
- builder() - Static method in class org.onosproject.net.meter.DefaultMeter
- builder() - Static method in class org.onosproject.net.meter.DefaultMeterFeatures
- builder() - Static method in class org.onosproject.net.meter.DefaultMeterRequest
- builder() - Static method in class org.onosproject.net.pi.model.DefaultPiPipeconf
-
Returns a new pipeconf builder.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiAction
-
Returns an action builder.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
-
Returns a new builder of action profile groups.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiActionProfileMember
-
Returns a new builder of action profile members.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
-
Returns a new builder of clone session entries.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiMatchKey
-
Returns a new builder of match keys.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
-
Returns a meter cell configuration builder.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
-
Returns a new builder of multicast group entries.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiPacketMetadata
-
Returns a packet metadata builder.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiPacketOperation
-
Returns a new builder of packet operations.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiRegisterCell
-
Returns a register cell entry builder.
- builder() - Static method in class org.onosproject.net.pi.runtime.PiTableEntry
-
Returns a table entry builder.
- builder() - Static method in class org.onosproject.net.PipelineTraceableOutput
-
Returns a new builder.
- builder() - Static method in class org.onosproject.store.service.WorkQueueStats
-
Returns a
WorkQueueStats
builder. - builder(ApplicationDescription) - Static method in class org.onosproject.core.DefaultApplication
-
Creates a new builder as a copy of an existing application description.
- builder(Application) - Static method in class org.onosproject.core.DefaultApplication
-
Creates a new builder as a copy of an existing application.
- builder(DefaultApplication.Builder) - Static method in class org.onosproject.core.DefaultApplication
-
Creates a new builder as a copy of an existing builder.
- builder(IpAssignment) - Static method in class org.onosproject.dhcp.IpAssignment
-
Creates and returns a new builder instance that clones an existing IPAssignment.
- builder(PortDescription) - Static method in class org.onosproject.net.device.DefaultPortDescription
-
Creates port description builder inheriting with default parameters, from specified port description.
- builder(PiCriterion) - Static method in class org.onosproject.net.flow.criteria.PiCriterion
-
Returns the PiCriterion builder initialized by the given PiCriterion.
- builder(TrafficSelector) - Static method in class org.onosproject.net.flow.DefaultTrafficSelector
-
Returns a new traffic selector builder primed to produce entities patterned after the supplied selector.
- builder(TrafficTreatment) - Static method in class org.onosproject.net.flow.DefaultTrafficTreatment
-
Returns a new traffic treatment builder primed to produce entities patterned after the supplied treatment.
- builder(ForwardingObjective) - Static method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
-
Returns a new builder primed to produce entities patterned after the supplied forwarding objective.
- builder(MultiPointToSinglePointIntent) - Static method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
-
Creates a new builder pre-populated with the information in the given intent.
- builder(SinglePointToMultiPointIntent) - Static method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
-
Creates a new builder pre-populated with the information in the given intent.
- builder(PipelineTraceableOutput) - Static method in class org.onosproject.net.PipelineTraceableOutput
-
Returns a new builder initialized with the traceable output.
- Builder() - Constructor for class org.onlab.util.KryoNamespace.Builder
- Builder() - Constructor for class org.onosproject.app.DefaultApplicationDescription.Builder
-
Default constructor for the builder.
- Builder() - Constructor for class org.onosproject.core.DefaultApplication.Builder
-
Default constructor for the builder.
- Builder() - Constructor for class org.onosproject.cpman.MetricValue.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.BandwidthProfile.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.BandwidthProfileAction.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.inbandtelemetry.IntObjective.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.protection.TransportEndpointDescription.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
- Builder() - Constructor for class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
- Builder() - Constructor for class org.onosproject.net.DefaultLink.Builder
- Builder() - Constructor for class org.onosproject.net.domain.DomainIntent.Builder
-
Creates a new empty builder.
- Builder() - Constructor for class org.onosproject.net.flow.DefaultFlowRule.Builder
- Builder() - Constructor for class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
- Builder() - Constructor for class org.onosproject.net.intent.ConnectivityIntent.Builder
-
Creates a new empty builder.
- Builder() - Constructor for class org.onosproject.net.intent.Intent.Builder
-
Creates a new empty builder.
- Builder() - Constructor for class org.onosproject.net.intent.OpticalCircuitIntent.Builder
- Builder() - Constructor for class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
- Builder() - Constructor for class org.onosproject.net.intent.OpticalOduIntent.Builder
- Builder() - Constructor for class org.onosproject.net.intent.OpticalPathIntent.Builder
- Builder() - Constructor for class org.onosproject.net.intent.PathIntent.Builder
- Builder() - Constructor for class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
-
Creates a new empty builder.
- Builder() - Constructor for class org.onosproject.net.meter.DefaultBand.Builder
- Builder() - Constructor for class org.onosproject.net.meter.DefaultMeter.Builder
- Builder() - Constructor for class org.onosproject.net.meter.DefaultMeterFeatures.Builder
- Builder() - Constructor for class org.onosproject.net.meter.DefaultMeterRequest.Builder
- Builder() - Constructor for class org.onosproject.net.pi.model.DefaultPiPipeconf.Builder
- Builder() - Constructor for class org.onosproject.store.primitives.MapUpdate.Builder
- Builder() - Constructor for class org.onosproject.store.primitives.NodeUpdate.Builder
- Builder() - Constructor for class org.onosproject.store.service.WorkQueueStats.Builder
- Builder(ClassLoader, List<UiView>) - Constructor for class org.onosproject.ui.UiExtension.Builder
-
Create a builder with the given class loader.
- Builder(String) - Constructor for class org.onosproject.ui.lion.LionBundle.Builder
-
Creates a builder of Lion Bundles.
- Builder(Alarm) - Constructor for class org.onosproject.alarm.DefaultAlarm.Builder
-
Constructs a Builder to create a Default Alarm based on another alarm.
- Builder(AlarmId, DeviceId, String, Alarm.SeverityLevel, long) - Constructor for class org.onosproject.alarm.DefaultAlarm.Builder
-
Constructs a Builder to create a Default Alarm.
- Builder(ApplicationDescription) - Constructor for class org.onosproject.core.DefaultApplication.Builder
-
Updates the builder to be a copy of an existing application description.
- Builder(Application) - Constructor for class org.onosproject.core.DefaultApplication.Builder
-
Updates the builder to be a copy of an existing application.
- Builder(DefaultApplication.Builder) - Constructor for class org.onosproject.core.DefaultApplication.Builder
-
Updates the builder to be a copy of an existing builder.
- Builder(ConnectivityIntent) - Constructor for class org.onosproject.net.intent.ConnectivityIntent.Builder
-
Creates a new builder pre-populated with the information in the given intent.
- Builder(Intent) - Constructor for class org.onosproject.net.intent.Intent.Builder
-
Creates a new builder pre-populated with the information in the given intent.
- Builder(MultiPointToSinglePointIntent) - Constructor for class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
-
Creates a new builder pre-populated with information from the given intent.
- Builder(ProtectionEndpointIntent) - Constructor for class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
-
Creates a new builder pre-populated with the information in the given intent.
- Builder(SinglePointToMultiPointIntent) - Constructor for class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
-
Creates a new builder pre-populated with information from the given intent.
- buildIcmp6Reply(Ethernet) - Static method in class org.onlab.packet.ICMP6
-
Builds an ICMPv6 reply using the supplied ICMPv6 request.
- buildIcmpReply(Ethernet) - Static method in class org.onlab.packet.ICMP
-
Builds an ICMP reply using the supplied ICMP request.
- BUILDING - org.onosproject.net.region.Region.Type
-
Region represents a building.
- buildMultimap() - Method in class org.onosproject.store.service.ConsistentMultimapBuilder
-
Builds the distributed multimap based on the configuration options supplied to this builder.
- buildNdpAdv(Ip6Address, MacAddress, Ethernet) - Static method in class org.onlab.packet.ndp.NeighborAdvertisement
-
Builds an NDP reply based on a request.
- buildNdpSolicit(Ip6Address, Ip6Address, Ip6Address, MacAddress, MacAddress, VlanId) - Static method in class org.onlab.packet.ndp.NeighborSolicitation
-
Builds a NDP solicitation using the supplied parameters.
- buildOduSignalId(OduSignalType, Set<TributarySlot>) - Static method in class org.onosproject.net.OduSignalUtils
-
Creates OduSignalId from OduSignalType and TributarySlots.
- buildPaths() - Method in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
-
Builds a set of paths for the specified src/dst vertex pair.
- buildTrafficSelector() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
-
Constructs a traffic selector based on the command line arguments presented to the command.
- buildTrafficTreatment() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
-
Generates a traffic treatment for this intent based on command line arguments presented to the command.
- buildTreeMap() - Method in class org.onosproject.store.service.ConsistentTreeMapBuilder
-
Builds the distributed tree map based on the configuration options supplied to this builder.
- burst() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
- burst() - Method in interface org.onosproject.net.behaviour.QueueDescription
-
Returns burst, Valid only in specific type.
- burst() - Method in interface org.onosproject.net.meter.Band
-
The burst size at which the meter applies.
- burst() - Method in class org.onosproject.net.meter.DefaultBand
- burst() - Method in class org.onosproject.net.meter.DefaultMeter.Builder
- burst() - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
- burst() - Method in interface org.onosproject.net.meter.Meter.Builder
-
Sets this meter as applicable to burst traffic only.
- burst() - Method in interface org.onosproject.net.meter.MeterRequest.Builder
-
Sets this meter as applicable to burst traffic only.
- burst() - Method in class org.onosproject.net.pi.runtime.PiMeterBand
-
Returns the burst of this band.
- burst(Long) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
- burst(Long) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
-
Returns queue description builder with a given burst.
- BURST - org.onosproject.net.behaviour.QueueDescription.Type
-
Support burst.
- burstSize() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
- burstSize() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
-
Maximum burst size subject to the SLAs specified for this token bucket.
- burstSize(long) - Method in interface org.onosproject.net.meter.Band.Builder
-
Assigns a burst size to this band.
- burstSize(long) - Method in class org.onosproject.net.meter.DefaultBand.Builder
- ButtonId - Class in org.onosproject.ui.topo
-
Designates the identity of a button on the topology view panels.
- ButtonId(String) - Constructor for class org.onosproject.ui.topo.ButtonId
-
Creates a button ID with the given identifier.
- buttons() - Method in class org.onosproject.ui.topo.PropertyPanel
-
Returns the list of button descriptors.
- BYTE - org.onosproject.cfg.ConfigProperty.Type
-
Indicates the value is a byte.
- BYTE_COUNT - org.onosproject.net.flow.StatTriggerField
-
Number of bytes in flow entry.
- BYTE_LENGTH - Static variable in class org.onlab.packet.Ip4Address
- BYTE_LENGTH - Static variable in class org.onlab.packet.Ip6Address
- ByteArraySizeHashPrinter - Class in org.onlab.util
-
Helper to print byte[] length and hashCode.
- ByteArraySizeHashPrinter(byte[]) - Constructor for class org.onlab.util.ByteArraySizeHashPrinter
- byteBuffertoArray(ByteBuffer) - Static method in class org.onlab.util.Tools
-
Returns the contents of
ByteBuffer
as byte array. - byteLength(IpAddress.Version) - Static method in class org.onlab.packet.IpAddress
-
Computes the IP address byte length for a given IP version.
- ByteOperator - Class in org.onlab.util
-
Provide a set of byte operations.
- bytes() - Method in class org.onosproject.net.behaviour.MirroringStatistics
-
Returns the transmitted bytes.
- bytes() - Method in class org.onosproject.net.flow.DefaultFlowEntry
- bytes() - Method in interface org.onosproject.net.flow.FlowEntry
-
Returns the number of bytes this flow rule has matched.
- bytes() - Method in class org.onosproject.net.group.DefaultGroup
-
Returns the number of bytes processed by this group.
- bytes() - Method in class org.onosproject.net.group.DefaultGroupBucket
- bytes() - Method in interface org.onosproject.net.group.Group
-
Returns the number of bytes processed by this group.
- bytes() - Method in interface org.onosproject.net.group.GroupBucket
-
Returns the number of bytes processed by this group bucket.
- bytes() - Method in interface org.onosproject.net.meter.Band
-
Return the bytes seen by this band.
- bytes() - Method in class org.onosproject.net.meter.DefaultBand
- bytes() - Method in class org.onosproject.net.pi.runtime.PiCounterCellData
-
Returns the byte count value contained by this counter data.
- BYTES - org.onosproject.net.pi.model.PiCounterModel.Unit
-
Counts only bytes.
- BYTES - org.onosproject.net.pi.model.PiMeterModel.Unit
-
Measures rate of bytes.
- BYTES - org.onosproject.net.statistic.PortStatisticsService.MetricType
-
Load is to be given in bytes/second.
- BYTES_UNIT - Static variable in class org.onosproject.ui.topo.TopoUtils
- bytesReceived() - Method in class org.onosproject.net.device.DefaultPortStatistics
- bytesReceived() - Method in interface org.onosproject.net.device.PortStatistics
-
Returns the bytes received.
- bytesSeen() - Method in class org.onosproject.net.meter.DefaultMeter
- bytesSeen() - Method in interface org.onosproject.net.meter.Meter
-
Number of bytes processed by this meter.
- bytesSent() - Method in class org.onosproject.net.device.DefaultPortStatistics
- bytesSent() - Method in interface org.onosproject.net.device.PortStatistics
-
Returns the bytes sent.
- bytesToHex(byte[]) - Static method in class org.onlab.packet.Ethernet
C
- C_BAND_MAX - Static variable in class org.onlab.util.Spectrum
- C_BAND_MIN - Static variable in class org.onlab.util.Spectrum
- cacheLionBundle(LionBundle) - Method in class org.onosproject.ui.UiMessageHandler
-
Invoked during initialization to cache any requested localization bundles in the handler's context, so that it may subsequently look up localization strings when composing data for the client.
- CALCULATE_PERFORMANCE_CHECK - Static variable in class org.onosproject.net.OsgiPropertyConstants
- CALCULATE_PERFORMANCE_CHECK_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
- callback() - Method in class org.onosproject.net.domain.DomainIntentOperations
-
Returns the callback for this batch of operations.
- callback() - Method in class org.onosproject.net.flow.FlowRuleOperations
-
Returns the callback for this batch of operations.
- callConstructor(Constructor<T>) - Static method in class org.onlab.junit.TestUtils
-
Triggers an allocation of an object of type T and forces a call to the private constructor.
- callMethod(T, String, Class<?>[], Object...) - Static method in class org.onlab.junit.TestUtils
-
Calls the method, bypassing scope restriction.
- callMethod(T, String, Class<?>, Object) - Static method in class org.onlab.junit.TestUtils
-
Calls the method, bypassing scope restriction.
- CAMPUS - org.onosproject.net.region.Region.Type
-
Region represents a campus.
- cancelPackets(TrafficSelector, PacketPriority, ApplicationId) - Method in interface org.onosproject.net.packet.PacketService
-
Cancels previous packet requests for packets matching the given selector to be punted from the dataplane to the controller.
- cancelPackets(TrafficSelector, PacketPriority, ApplicationId, Optional<DeviceId>) - Method in interface org.onosproject.net.packet.PacketService
-
Cancels previous packet requests for packets matching the given selector to be punted from the dataplane to the controller.
- cancelPackets(PacketRequest) - Method in interface org.onosproject.net.packet.PacketStore
-
Cancels intercept of packets that match the given selector.
- cancelPackets(PacketRequest) - Method in interface org.onosproject.net.packet.PacketStoreDelegate
-
Requests that packets matching to following request no longer be collected from any switches.
- candidates() - Method in class org.onosproject.cluster.Leadership
-
Returns an preference-ordered list of nodes that are in the leadership race for this topic.
- CANDIDATES_CHANGED - org.onosproject.cluster.LeadershipEvent.Type
-
Signifies a change in the list of candidates for a topic.
- canonicalLinkKey(Link) - Static method in class org.onosproject.ui.topo.TopoUtils
-
Produces a canonical link key, that is, one that will match both a link and its inverse.
- capacity() - Method in class org.onosproject.net.config.basics.BandwidthCapacity
-
Available Bandwidth resource (Capacity).
- capacity(Bandwidth) - Method in class org.onosproject.net.config.basics.BandwidthCapacity
-
Sets the Available Bandwidth resource (Capacity).
- category() - Method in interface org.onosproject.app.ApplicationDescription
-
Returns category of the application.
- category() - Method in class org.onosproject.app.DefaultApplicationDescription
- category() - Method in interface org.onosproject.core.Application
-
Returns category of the application.
- category() - Method in class org.onosproject.core.DefaultApplication
- category() - Method in class org.onosproject.ui.UiView
-
Returns the navigation category.
- CAUSE - Static variable in class org.onlab.junit.ExceptionTest
- cbs() - Method in class org.onosproject.net.behaviour.BandwidthProfile
-
Obtains the committed burst size (CBS) of this bandwidth profile.
- cbs() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
- cbs() - Method in interface org.onosproject.net.behaviour.QosDescription
-
Returns Committed Burst Size of Qos, Valid only in specific qos type.
- cbs(Integer) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
-
Sets the committed burst size (CBS) of this builder.
- cbs(Long) - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
- cbs(Long) - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
-
Returns qos description builder with a given cbs.
- ceilingEntry(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- ceilingEntry(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
-
Returns the entry associated with the least key greater than or equal to the key.
- ceilingEntry(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
-
Returns the entry associated with the least key greater than or equal to the key.
- ceilingKey(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- ceilingKey(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
-
Return the lowest key greater than or equal to key.
- ceilingKey(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
-
Returns the lowest key greater than or equal to key.
- cell(String, Object) - Method in class org.onosproject.ui.table.TableModel.Row
-
Sets the cell value for the given column of this row.
- CellComparator - Interface in org.onosproject.ui.table
-
Defines a comparator for cell values.
- CellFormatter - Interface in org.onosproject.ui.table
-
Defines a formatter for cell values.
- cellId() - Method in class org.onosproject.net.pi.runtime.PiCounterCell
-
Returns the cell identifier.
- cellId() - Method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
-
Returns the counter cell ID associated with this handle.
- cellId() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
-
Returns the cell identifier.
- cellId() - Method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
-
Returns the cell ID associated with this handle.
- cellId() - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
-
Returns the cell identifier.
- CENTER_FREQUENCY - Static variable in class org.onlab.util.Spectrum
- centralFrequency() - Method in class org.onosproject.net.OchSignal
-
Returns central frequency in MHz.
- chain(String, ObjectNode) - Method in class org.onosproject.ui.RequestHandler
-
Allows one request handler to pass the event on to another for further processing.
- CHAIN - Static variable in class org.onosproject.ui.GlyphConstants
- CHAINED_GROUP - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
- CHAINING_UNSUPPORTED - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
- Change<T> - Class in org.onosproject.event
-
Generic representation of an update.
- Change(T, T) - Constructor for class org.onosproject.event.Change
- CHANGE_TO_EXCLUDE_MODE - Static variable in class org.onlab.packet.IGMPMembership
- CHANGE_TO_INCLUDE_MODE - Static variable in class org.onlab.packet.IGMPMembership
- changeConfiguration(RouterInfo, boolean) - Method in class org.onosproject.routing.Router
-
Changes the router configuration.
- changePortState(DeviceId, PortNumber, boolean) - Method in interface org.onosproject.net.device.DeviceAdminService
-
Administratively enables or disables a port on a device.
- changePortState(DeviceId, PortNumber, boolean) - Method in interface org.onosproject.net.device.DeviceProvider
-
Administratively enables or disables a port.
- CHANNEL_CLOSED - org.onosproject.net.device.DeviceAgentEvent.Type
-
Signifies that a channel between the agent and the device is closed and the two cannot communicate.
- CHANNEL_ERROR - org.onosproject.net.device.DeviceAgentEvent.Type
-
Signifies that a channel error has been detected.
- CHANNEL_ID - Static variable in class org.onosproject.net.AnnotationKeys
-
Annotation key for the channel id.
- CHANNEL_OPEN - org.onosproject.net.device.DeviceAgentEvent.Type
-
Signifies that a channel between the agent and the device is open and the two can communicate.
- channelSpacing() - Method in class org.onosproject.net.OchSignal
-
Returns channel spacing.
- ChannelSpacing - Enum in org.onosproject.net
-
Represents interval frequency between two neighboring wavelengths.
- charAt(int) - Method in class org.onlab.util.XmlString
- ChartModel - Class in org.onosproject.ui.chart
-
A simple model of time series chart data.
- ChartModel(String...) - Constructor for class org.onosproject.ui.chart.ChartModel
-
Constructs a chart model with initialized series set.
- ChartModel.Annot - Class in org.onosproject.ui.chart
-
Model of an annotation.
- ChartModel.DataPoint - Class in org.onosproject.ui.chart
-
A class of data point.
- ChartRequestHandler - Class in org.onosproject.ui.chart
-
Message handler specifically for the chart views.
- ChartRequestHandler(String, String, String) - Constructor for class org.onosproject.ui.chart.ChartRequestHandler
-
Constructs a chart model handler for a specific graph view.
- ChartUtils - Class in org.onosproject.ui.chart
-
Provides static utility methods for dealing with charts.
- CHASSIS_TLV_SIZE - Static variable in class org.onlab.packet.LLDP
- CHASSIS_TLV_SUBTYPE - Static variable in class org.onlab.packet.LLDP
- CHASSIS_TLV_TYPE - Static variable in class org.onlab.packet.LLDP
- chassisId - Variable in class org.onlab.packet.LLDP
- chassisId() - Method in class org.onosproject.net.DefaultDevice
- chassisId() - Method in interface org.onosproject.net.Device
-
Returns the device chassis id.
- chassisId() - Method in class org.onosproject.net.device.DefaultDeviceDescription
- chassisId() - Method in interface org.onosproject.net.device.DeviceDescription
-
Returns a device chassis id.
- chassisId() - Method in interface org.onosproject.net.utils.ForwardingDevice
- ChassisId - Class in org.onlab.packet
-
The class representing a network device chassisId.
- ChassisId() - Constructor for class org.onlab.packet.ChassisId
-
Default constructor.
- ChassisId(long) - Constructor for class org.onlab.packet.ChassisId
-
Constructor from a long value.
- ChassisId(String) - Constructor for class org.onlab.packet.ChassisId
-
Constructor from a string.
- CHECK_MARK - Static variable in class org.onosproject.ui.GlyphConstants
- checkArguments(Graph<V, E>, V, V) - Method in class org.onlab.graph.AbstractGraphPathSearch
-
Checks the specified path search arguments for validity.
- checkBufferLength(int, int, int) - Static method in class org.onlab.packet.PacketUtils
-
Check the length of the input buffer is appropriate given the offset and length parameters.
- checkHeaderLength(int, int) - Static method in class org.onlab.packet.PacketUtils
-
Check that there are enough bytes in the buffer to read some number of bytes that we need to read a full header.
- checkInput(byte[], int, int, int) - Static method in class org.onlab.packet.PacketUtils
-
Check the input parameters are sane and there's enough bytes to read the required length.
- checkMessageAuthenticator(String) - Method in class org.onlab.packet.RADIUS
-
Checks the message authenticator in the packet with one generated from the given key.
- checkPermission(AppPermission.Type) - Static method in class org.onosproject.security.AppGuard
-
Checks if the caller has the required permission only when security-mode is enabled.
- checksum - Variable in class org.onlab.packet.ICMP
- checksum - Variable in class org.onlab.packet.ICMP6
- checksum - Variable in class org.onlab.packet.IGMP
- checksum - Variable in class org.onlab.packet.IPv4
- checksum - Variable in class org.onlab.packet.PIM
- checksum - Variable in class org.onlab.packet.TCP
- checksum - Variable in class org.onlab.packet.UDP
- checkValidity() - Method in class org.onosproject.net.provider.AbstractProviderService
-
Checks the validity of this provider service.
- child(Class<?>) - Method in class org.onosproject.net.resource.ContinuousResourceId
-
Returns a resource ID of a child of this resource based on the specified object.
- child(Class<?>) - Method in class org.onosproject.net.resource.DiscreteResourceId
- child(Class<?>) - Method in class org.onosproject.net.resource.ResourceId
-
Returns a resource ID of a child of this resource based on the specified object.
- child(Class<?>, double) - Method in class org.onosproject.net.resource.ContinuousResource
- child(Class<?>, double) - Method in class org.onosproject.net.resource.DiscreteResource
- child(Class<?>, double) - Method in interface org.onosproject.net.resource.Resource
-
Returns a child resource of this instance with specifying a child object and value.
- child(Object) - Method in class org.onosproject.net.resource.ContinuousResource
- child(Object) - Method in class org.onosproject.net.resource.ContinuousResourceId
-
Returns a resource ID of a child of this resource based on the specified object.
- child(Object) - Method in class org.onosproject.net.resource.DiscreteResource
- child(Object) - Method in class org.onosproject.net.resource.DiscreteResourceId
- child(Object) - Method in interface org.onosproject.net.resource.Resource
-
Returns a child resource of this instance with specifying the child object.
- child(Object) - Method in class org.onosproject.net.resource.ResourceId
-
Returns a resource ID of a child of this resource based on the specified object.
- child(String) - Method in interface org.onosproject.store.service.DocumentTreeNode
-
Returns the child node of this node with the specified relative path name.
- childPath() - Method in class org.onosproject.store.service.DocumentPath
-
Returns the relative path to the given node.
- children() - Method in interface org.onosproject.store.service.DocumentTreeNode
-
Returns the children of this node.
- children() - Method in class org.onosproject.ui.model.topo.UiRegion
-
Returns the identities of the child regions.
- CHL_0GHZ - org.onosproject.net.ChannelSpacing
- CHL_100GHZ - org.onosproject.net.ChannelSpacing
- CHL_12P5GHZ - org.onosproject.net.ChannelSpacing
- CHL_25GHZ - org.onosproject.net.ChannelSpacing
- CHL_50GHZ - org.onosproject.net.ChannelSpacing
- CHL_6P25GHZ - org.onosproject.net.ChannelSpacing
- choices() - Method in class org.onosproject.cli.AbstractChoicesCompleter
- choices() - Method in class org.onosproject.cli.app.AllApplicationNamesCompleter
- choices() - Method in class org.onosproject.cli.app.ApplicationCommandCompleter
- choices() - Method in class org.onosproject.cli.cfg.ConfigKeyCompleter
- choices() - Method in class org.onosproject.cli.cfg.SubjectClassKeyCompleter
- choices() - Method in class org.onosproject.cli.cfg.SubjectKeyCompleter
- choices() - Method in class org.onosproject.cli.MetricNameCompleter
- choices() - Method in class org.onosproject.cli.net.completer.AnnotationKeysCompleter
- choices() - Method in class org.onosproject.cli.net.completer.IntentIdCompleter
- choices() - Method in class org.onosproject.cli.net.completer.InterfaceNameCompleter
- choices() - Method in class org.onosproject.cli.net.completer.LinkTypeCompleter
- choices() - Method in class org.onosproject.cli.net.completer.NumericPortNumberCompleter
- choices() - Method in class org.onosproject.cli.net.completer.PeerConnectPointCompleter
- choices() - Method in class org.onosproject.cli.net.GroupStatusCompleter
- choices() - Method in class org.onosproject.cli.net.GroupTypeCompleter
- choices() - Method in class org.onosproject.cli.net.McastGroupCompleter
- choices() - Method in class org.onosproject.cli.net.PortNumberCompleter
- choices() - Method in class org.onosproject.cli.net.PortStateCompleter
- choices() - Method in class org.onosproject.cli.net.RegionIdCompleter
- choices() - Method in class org.onosproject.cli.net.RegionTypeCompleter
- choices() - Method in class org.onosproject.cli.StartStopCompleter
- choices() - Method in class org.onosproject.cli.UpDownCompleter
- cir() - Method in class org.onosproject.net.behaviour.BandwidthProfile
-
Obtains the committed information rate (CIR) of this bandwidth profile.
- cir() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
- cir() - Method in interface org.onosproject.net.behaviour.QosDescription
-
Returns Committed Information Rate of Qos, Valid only in specific qos type.
- cir(Long) - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
- cir(Long) - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
-
Returns qos description builder with a given cir.
- cir(Bandwidth) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
-
Sets the committed information rate (CIR) of this builder.
- CIRCUIT_ID - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
- CircuitId - Class in org.onlab.packet.dhcp
-
Representation of DHCP option 82 Circuit id.
- CircuitId(String, VlanId) - Constructor for class org.onlab.packet.dhcp.CircuitId
-
Creates a circuit id by given information.
- classname - Variable in class org.onosproject.security.Permission
- classOfService() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
-
Returns the class of service associated to the replicas produced by this clone session.
- cleanup() - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
-
Clean up any INT-related configuration from the device.
- cleanup() - Method in class org.onosproject.routing.Router
-
Cleans up the router and unprovisions all interfaces.
- cleanUp(ApplicationId) - Method in interface org.onosproject.net.behaviour.BngProgrammable
-
Remove any state previously created by this API for the given application ID.
- clear() - Method in class org.onlab.graph.MutableAdjacencyListsGraph
-
Clear the graph.
- clear() - Method in class org.onlab.metrics.MetricsManager
-
Clears the internal state.
- clear() - Method in class org.onlab.util.ExtendedSet
- clear() - Method in class org.onlab.util.SlidingWindowCounter
-
Clears the counter.
- clear() - Method in class org.onlab.util.UnmodifiableDeque
- clear() - Method in class org.onosproject.alarm.DefaultAlarm.Builder
-
Clears the alarm that is being created.
- clear() - Method in class org.onosproject.net.flow.BatchOperation
-
Removes all operations maintained in this object.
- clear() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- clear() - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
- clear() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- clear() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
- clear() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- clear() - Method in class org.onosproject.store.primitives.DefaultDistributedSet
- clear() - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
-
Removes all entries from the map.
- clear() - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Removes all of the mappings from this map (optional operation).
- clear() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Removes all key-value pairs, after which it will be empty.
- clear() - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Removes all elements from the set.
- clear() - Method in interface org.onosproject.store.service.AtomicCounterMap
-
Clears all entries from the map.
- clear() - Method in interface org.onosproject.store.service.ConsistentMap
-
Removes all of the mappings from this map (optional operation).
- clear() - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Removes all key-value pairs, after which it will be empty.
- clear() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
-
Removes all mappings from this map.
- clear() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Clears the topology state; that is, drops all regions, devices, hosts, links, and cluster members.
- clear(String) - Method in class org.onosproject.net.config.Config
-
Clears the specified property.
- clear(String...) - Method in class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
- clear(String...) - Method in class org.onosproject.net.driver.DefaultDriverData
- clear(String...) - Method in interface org.onosproject.net.MutableAnnotations
-
Clears the specified keys or the all keys if none were specified.
- clearActive(String) - Method in class org.onosproject.common.app.ApplicationArchive
-
Clears the app as active by deleting token file in the app directory.
- clearConfig() - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Clears the complete configuration including queued.
- clearConfig(S) - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Clears the configuration based on the subject including queued.
- clearConfig(S, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Clears the configuration of the given class for the specified subject.
- cleared() - Method in interface org.onosproject.alarm.Alarm
-
Returns a flag to indicate if this alarm has been cleared.
- cleared() - Method in class org.onosproject.alarm.DefaultAlarm
- CLEARED - org.onosproject.alarm.Alarm.SeverityLevel
-
From X.733: This indicates the clearing of one or more previously reported alarms.
- clearedDeferred() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
- clearedDeferred() - Method in interface org.onosproject.net.flow.TrafficTreatment
-
Whether the deferred treatment instructions will be cleared by the device.
- clearFilters() - Method in interface org.onosproject.net.packet.PacketService
-
Clear all packet filters in one shot.
- clearQueue() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
- clearQueuedConfig(S, String) - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Clears the configuration of the given class for the specified subject.
- CliComponent - Class in org.onosproject.cli
-
OSGI Component for the ONOS CLI.
- CliComponent() - Constructor for class org.onosproject.cli.CliComponent
- CLIENT_DATA - org.onlab.packet.DHCP6.OptionCode
- CLIENT_LT - org.onlab.packet.DHCP6.OptionCode
- clientHardwareAddress - Variable in class org.onlab.packet.DHCP
- CLIENTID - org.onlab.packet.DHCP6.OptionCode
- clientIPAddress - Variable in class org.onlab.packet.DHCP
- clipG(double) - Method in class org.onosproject.ui.topo.TopoUtils.ValueLabel
-
Clips the (adjusted) value to the given threshold expressed in Giga units.
- clipped() - Method in class org.onosproject.ui.topo.TopoUtils.ValueLabel
-
Returns true if this value was clipped to a maximum threshold.
- CLOCK_WRITE - org.onosproject.security.AppPermission.Type
- clone() - Method in class org.onlab.packet.BasePacket
-
This implementation of clone() is here to preserve backwards compatibility.
- CLONE - org.onosproject.net.group.GroupDescription.Type
-
Similar to
GroupDescription.Type.ALL
but used for cloning of packets independently of the egress decision (singleton treatment or other group). - CLONE_SESSION - org.onosproject.net.pi.runtime.PiPreEntryType
-
Clone session entry.
- CLOSED - org.onosproject.store.primitives.PartitionEvent.Type
-
Signifies that a partition has been successfully closed.
- ClosedOpenRange - Class in org.onlab.util
-
Represent a closed-open range.
- CLOUD - Static variable in class org.onosproject.ui.GlyphConstants
- CLT_100GBE - org.onosproject.net.CltSignalType
- CLT_10GBE - org.onosproject.net.CltSignalType
- CLT_1GBE - org.onosproject.net.CltSignalType
-
bit rate in Mbps.
- CLT_40GBE - org.onosproject.net.CltSignalType
- CltSignalType - Enum in org.onosproject.net
-
Represents ODU (Optical channel Data Unit) client port signal type.
- cluster() - Method in interface org.onosproject.ui.model.ServiceBundle
-
Reference to a cluster service implementation.
- CLUSTER_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
- CLUSTER_EVENT - org.onosproject.security.AppPermission.Type
- CLUSTER_MEMBER_ADDED_OR_UPDATED - org.onosproject.ui.model.topo.UiModelEvent.Type
- CLUSTER_MEMBER_REMOVED - org.onosproject.ui.model.topo.UiModelEvent.Type
- CLUSTER_READ - org.onosproject.security.AppPermission.Type
- CLUSTER_WRITE - org.onosproject.security.AppPermission.Type
- ClusterActivator - Class in org.onosproject.store.atomix
- ClusterActivator() - Constructor for class org.onosproject.store.atomix.ClusterActivator
- ClusterAdminService - Interface in org.onosproject.cluster
-
Service for administering the cluster node membership.
- ClusterCommunicationService - Interface in org.onosproject.store.cluster.messaging
-
Service for assisting communications between controller cluster nodes.
- clusterCommunicator - Variable in class org.onosproject.store.app.DistributedApplicationStore
- clusterCount() - Method in class org.onlab.graph.TarjanGraphSearch.SccResult
-
Returns the number of SCC clusters in the graph.
- clusterCount() - Method in class org.onosproject.common.DefaultTopology
- clusterCount() - Method in interface org.onosproject.net.topology.Topology
-
Returns the number of SCCs (strongly connected components) in the topology.
- ClusterDevicesCommand - Class in org.onosproject.cli.net
-
Lists devices of the specified topology cluster in the current topology.
- ClusterDevicesCommand() - Constructor for class org.onosproject.cli.net.ClusterDevicesCommand
- clusterEdges() - Method in class org.onlab.graph.TarjanGraphSearch.SccResult
-
Returns the list of edges linking strongly connected vertex clusters.
- ClusterEvent - Class in org.onosproject.cluster
-
Describes cluster-related event.
- ClusterEvent(ClusterEvent.Type, ControllerNode) - Constructor for class org.onosproject.cluster.ClusterEvent
-
Creates an event of a given type and for the specified instance and the current time.
- ClusterEvent(ClusterEvent.Type, ControllerNode, long) - Constructor for class org.onosproject.cluster.ClusterEvent
-
Creates an event of a given type and for the specified device and time.
- ClusterEvent.Type - Enum in org.onosproject.cluster
-
Type of cluster-related events.
- ClusterEventListener - Interface in org.onosproject.cluster
-
Entity capable of receiving device cluster-related events.
- clusterId(int) - Static method in class org.onosproject.net.topology.ClusterId
-
Returns the cluster identifier, represented by the specified integer serial number.
- ClusterId - Class in org.onosproject.net.topology
-
Representation of the topology cluster identity.
- ClusterIdCompleter - Class in org.onosproject.cli.net
-
Cluster ID completer.
- ClusterIdCompleter() - Constructor for class org.onosproject.cli.net.ClusterIdCompleter
- ClusterLinksCommand - Class in org.onosproject.cli.net
-
Lists links of the specified topology cluster in the current topology.
- ClusterLinksCommand() - Constructor for class org.onosproject.cli.net.ClusterLinksCommand
- clusterMemberCount() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Returns the number of members in the cluster.
- ClusterMessage - Class in org.onosproject.store.cluster.messaging
-
Base message for cluster-wide communications.
- ClusterMessage(NodeId, MessageSubject, byte[]) - Constructor for class org.onosproject.store.cluster.messaging.ClusterMessage
-
Creates a cluster message.
- ClusterMessageHandler - Interface in org.onosproject.store.cluster.messaging
-
Deprecated.since 1.11 ("Loon")
- ClusterMetadata - Class in org.onosproject.cluster
-
Cluster metadata.
- ClusterMetadata(String, ControllerNode, Set<ControllerNode>, Set<Node>) - Constructor for class org.onosproject.cluster.ClusterMetadata
-
Deprecated.since 1.15.
- ClusterMetadata(String, ControllerNode, Set<ControllerNode>, Set<Node>, String) - Constructor for class org.onosproject.cluster.ClusterMetadata
- ClusterMetadata(ProviderId, String, ControllerNode, Set<ControllerNode>, String, Set<Node>) - Constructor for class org.onosproject.cluster.ClusterMetadata
-
Deprecated.since 1.15.
- ClusterMetadata(ProviderId, String, ControllerNode, Set<ControllerNode>, String, Set<Node>, String) - Constructor for class org.onosproject.cluster.ClusterMetadata
- ClusterMetadata(ProviderId, String, ControllerNode, Set<ControllerNode>, Set<Node>, String) - Constructor for class org.onosproject.cluster.ClusterMetadata
- ClusterMetadataAdminService - Interface in org.onosproject.cluster
-
Service for making updates to
cluster metadata
. - clusterMetadataChanged(Versioned<ClusterMetadata>) - Method in interface org.onosproject.cluster.ClusterMetadataProviderService
-
Notifies about a change to cluster metadata.
- ClusterMetadataDiff - Class in org.onosproject.cluster
-
Deprecated.since 1.14
- ClusterMetadataDiff(ClusterMetadata, ClusterMetadata) - Constructor for class org.onosproject.cluster.ClusterMetadataDiff
-
Deprecated.
- ClusterMetadataEvent - Class in org.onosproject.cluster
-
Describes a cluster metadata event.
- ClusterMetadataEvent(ClusterMetadataEvent.Type, ClusterMetadata) - Constructor for class org.onosproject.cluster.ClusterMetadataEvent
-
Creates an event of a given type and for the specified metadata and the current time.
- ClusterMetadataEvent(ClusterMetadataEvent.Type, ClusterMetadata, long) - Constructor for class org.onosproject.cluster.ClusterMetadataEvent
-
Creates an event of a given type and for the specified metadata and time.
- ClusterMetadataEvent.Type - Enum in org.onosproject.cluster
-
Type of cluster metadata events.
- ClusterMetadataEventListener - Interface in org.onosproject.cluster
-
Entity capable of receiving cluster metadata related events.
- ClusterMetadataProvider - Interface in org.onosproject.cluster
-
Abstraction of a
cluster metadata
provider. - ClusterMetadataProviderRegistry - Interface in org.onosproject.cluster
-
Abstraction of a cluster metadata provider registry.
- ClusterMetadataProviderService - Interface in org.onosproject.cluster
-
Service through which a
provider
can notify core of updates made to cluster metadata. - ClusterMetadataService - Interface in org.onosproject.cluster
-
Service for accessing
cluster metadata
. - clusterSecretChanged() - Method in class org.onosproject.cluster.ClusterMetadataDiff
-
Deprecated.Returns whether the cluster-wide shared secret changed.
- clusterService - Variable in class org.onosproject.store.app.DistributedApplicationStore
- ClusterService - Interface in org.onosproject.cluster
-
Service for obtaining information about the individual nodes within the controller cluster.
- ClustersListCommand - Class in org.onosproject.cli.net
-
Lists all clusters in the current topology.
- ClustersListCommand() - Constructor for class org.onosproject.cli.net.ClustersListCommand
- ClusterStore - Interface in org.onosproject.cluster
-
Manages inventory of controller cluster nodes; not intended for direct use.
- ClusterStoreDelegate - Interface in org.onosproject.cluster
-
Cluster store delegate abstraction.
- clusterVertexes() - Method in class org.onlab.graph.TarjanGraphSearch.SccResult
-
Returns the list of strongly connected vertex clusters.
- cmdType - Variable in class org.onlab.packet.RIP
- cmdType - Variable in class org.onlab.packet.RIPng
- code - Variable in class org.onlab.packet.dhcp.DhcpOption
- code - Variable in class org.onlab.packet.EAP
- code - Variable in class org.onlab.packet.PPPoED
- code - Variable in class org.onlab.packet.RADIUS
- code() - Method in enum org.onosproject.ui.topo.NodeBadge.Status
- CODE_ECHO_REPLY - Static variable in class org.onlab.packet.ICMP
- CODE_ECHO_REQEUST - Static variable in class org.onlab.packet.ICMP
- codec(Class<T>) - Method in class org.onosproject.cli.AbstractShellCommand
- codec(Class<T>) - Method in interface org.onosproject.codec.CodecContext
-
Returns the JSON codec for the specified entity class.
- codec(Class<T>) - Method in class org.onosproject.net.config.BaseConfig
- codec(Class<T>) - Method in class org.onosproject.rest.AbstractWebResource
-
Returns the JSON codec for the specified entity class.
- CODEC_READ - org.onosproject.security.AppPermission.Type
- CODEC_WRITE - org.onosproject.security.AppPermission.Type
- CodecContext - Interface in org.onosproject.codec
-
Context for codecs to use while encoding/decoding.
- CodecService - Interface in org.onosproject.codec
-
Service for registering and retrieving JSON codecs for various entities.
- CODEL - org.onosproject.net.behaviour.QosDescription.Type
-
Corresponds to Controlled Delay classifier classifier.
- collectorIp() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
-
Returns IP address of the collector.
- collectorIp() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
-
IP address of the collector.
- collectorNextHopMac() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
-
Returns MAC address of next hop of INT report packets.
- collectorNextHopMac() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
-
Returns MAC address of next hop of INT report packets.
- collectorPort() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
-
Returns UDP port number of the collector.
- collectorPort() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
-
UDP port number of the collector.
- colorAware() - Method in class org.onosproject.net.behaviour.BandwidthProfile
-
Obtains the color-aware mode of the bandwidth profile.
- colorAware(boolean) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
-
Sets the color-aware mode of this builder.
- colorAware(boolean) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
- colorAware(boolean) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
-
Sets this policer to be color aware.
- columnCount() - Method in class org.onosproject.ui.table.TableModel
-
Returns the number of columns in this table model.
- combine(ConnectPoint, PortDescription) - Method in interface org.onosproject.net.config.PortConfigOperator
-
Deprecated.onos-2.0
- combine(ConnectPoint, PortDescription, Optional<Config>) - Method in interface org.onosproject.net.config.PortConfigOperator
-
Generates a PortDescription containing fields from a PortDescription and configuration.
- combine(DeviceId, DeviceDescription, Optional<Config>) - Method in interface org.onosproject.net.config.DeviceConfigOperator
-
Generates a DeviceDescription containing fields from a DeviceDescription and configuration.
- combine(DeviceId, PortDescription) - Method in interface org.onosproject.net.config.PortConfigOperator
-
Generates a PortDescription containing fields from a PortDescription and configuration.
- combine(HostId, HostDescription, Optional<Config>) - Method in interface org.onosproject.net.config.HostConfigOperator
-
Generates a HostDescription containing fields from a HostDescription and configuration.
- COMM_PROHIBIT - org.onosproject.cli.net.Icmp6Code
-
Communication with destination administratively prohibited.
- COMM_PROHIBIT - Static variable in class org.onlab.packet.ICMP6
-
Communication with destination administratively prohibited.
- commandLine - Variable in class org.onosproject.cli.AbstractChoicesCompleter
- commit() - Method in interface org.onosproject.store.service.TransactionContext
-
Commits a transaction that was previously started thereby making its changes permanent and externally visible.
- commit() - Method in interface org.onosproject.upgrade.UpgradeAdminService
-
Commits an upgrade.
- commit(TransactionId) - Method in interface org.onosproject.store.service.Transactional
-
Commits a previously prepared transaction and unlocks the object.
- CommitStatus - Enum in org.onosproject.store.service
-
Completion status of transaction.
- COMMITTED - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Type
-
Committed rate.
- COMMITTED - org.onosproject.upgrade.Upgrade.Status
-
Indicates that an upgrade has been committed.
- COMMITTED - org.onosproject.upgrade.UpgradeEvent.Type
-
Indicates that an upgrade was committed.
- COMMITTING - org.onosproject.upgrade.Upgrade.Status
-
d Indicates that an upgrade is being committed.
- COMMUNITY_NAME - org.onosproject.net.key.DeviceKey.Type
- CommunityName - Class in org.onosproject.net.key
-
Representation of an SNMP community name authentication token.
- compactLinkString(Link) - Static method in class org.onosproject.cli.net.LinksListCommand
-
Returns a compact string representing the given link.
- compactLinkString(Link) - Static method in class org.onosproject.ui.topo.TopoUtils
-
Returns a compact identity for the given link, in the form used to identify links in the Topology View on the client.
- Comparators - Class in org.onosproject.utils
-
Various comparators.
- compare(Object, Object) - Method in class org.onosproject.ui.table.cell.AbstractCellComparator
- compare(Object, Object) - Method in interface org.onosproject.ui.table.CellComparator
-
Compares its two arguments for order.
- compare(OchSignal, OchSignal) - Method in class org.onosproject.net.DefaultOchSignalComparator
- compareAndSet(long, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
- compareAndSet(long, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounter
-
Atomically sets the given counter to the updated value if the current value is the expected value, otherwise no change occurs.
- compareAndSet(long, long) - Method in interface org.onosproject.store.service.AtomicCounter
-
Atomically sets the given counter to the updated value if the current value is the expected value, otherwise no change occurs.
- compareAndSet(V, V) - Method in class org.onosproject.store.primitives.DefaultAtomicValue
- compareAndSet(V, V) - Method in interface org.onosproject.store.service.AsyncAtomicValue
-
Atomically sets the value to the given updated value if the current value is equal to the expected value.
- compareAndSet(V, V) - Method in interface org.onosproject.store.service.AtomicValue
-
Atomically sets the value to the given updated value if the current value is equal to the expected value.
- compareTo(Weight) - Method in class org.onlab.graph.ScalarWeight
- compareTo(IpAddress) - Method in class org.onlab.packet.IpAddress
- compareTo(Bandwidth) - Method in interface org.onlab.util.Bandwidth
- compareTo(Frequency) - Method in class org.onlab.util.Frequency
- compareTo(NodeId) - Method in class org.onosproject.cluster.NodeId
- compareTo(PartitionId) - Method in class org.onosproject.cluster.PartitionId
- compareTo(Version) - Method in class org.onosproject.core.Version
- compareTo(ConnectPoint) - Method in class org.onosproject.net.ConnectPoint
- compareTo(TableId) - Method in class org.onosproject.net.flow.IndexTableId
- compareTo(TableId) - Method in interface org.onosproject.net.flow.TableId
-
Compares table ID.
- compareTo(TableId) - Method in class org.onosproject.net.pi.model.PiTableId
- compareTo(DocumentPath) - Method in class org.onosproject.store.service.DocumentPath
- compareTo(Timestamp) - Method in class org.onosproject.store.LogicalTimestamp
- compareTo(Timestamp) - Method in class org.onosproject.store.service.MultiValuedTimestamp
- compareTo(Timestamp) - Method in class org.onosproject.store.service.Version
- compareTo(Timestamp) - Method in class org.onosproject.store.service.WallClockTimestamp
- compareTo(LionBundle.LionItem) - Method in class org.onosproject.ui.lion.LionBundle.LionItem
- compareTo(Mod) - Method in class org.onosproject.ui.topo.Mod
- compatibilityFunction - Variable in class org.onosproject.store.service.AtomicValueOptions
- compatibilityFunction - Variable in class org.onosproject.store.service.ConsistentMapOptions
- compatibilityFunction - Variable in class org.onosproject.store.service.TopicOptions
- compile(T, List<Intent>) - Method in interface org.onosproject.net.intent.IntentCompiler
-
Compiles the specified intent into other intents.
- compiled(IntentData, List<Intent>) - Static method in class org.onosproject.net.intent.IntentData
-
Creates updated IntentData with compilation result.
- COMPILING - org.onosproject.net.intent.IntentState
-
Signifies that the intent is being compiled into installable intents.
- complete(String...) - Method in interface org.onosproject.store.service.WorkQueue
-
Completes a collection of tasks.
- complete(Collection<String>) - Method in interface org.onosproject.store.service.WorkQueue
-
Completes a collection of tasks.
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.AbstractChoicesCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.AbstractCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.app.ApplicationIdWithIntentNameCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.app.ApplicationNameCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.cfg.ComponentConfigCommandCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.cfg.ComponentNameCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.cfg.ComponentPropertyNameCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.ClusterIdCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.ConnectPointCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.DeviceIdCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.DomainIdCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.DriverNameCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.EncapTypeCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.EthTypeCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.ExtHeaderCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.FlowRuleStatusCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.HostIdCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.Icmp6CodeCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.Icmp6TypeCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.IntentKeyCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.IpProtocolCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.LinkDstCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.LinkSrcCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.NetconfOperationCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.OpticalConnectPointCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.net.RoleCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.NodeIdCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.PlaceholderCompleter
- complete(Session, CommandLine, List<String>) - Method in class org.onosproject.cli.security.ReviewApplicationNameCompleter
- completeAfter(long, TimeUnit) - Static method in class org.onlab.util.Tools
-
Returns a future that completes normally after given time period.
- completed(FlowRuleBatchRequest, CompletedBatchOperation) - Static method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent
-
Deprecated.Constructs a new FlowRuleBatchEvent.
- CompletedBatchOperation - Class in org.onosproject.net.flow
-
Representation of a completed flow rule batch operation.
- CompletedBatchOperation(boolean, Set<? extends FlowRule>, Set<Long>, DeviceId) - Constructor for class org.onosproject.net.flow.CompletedBatchOperation
-
Creates a new batch completion result.
- CompletedBatchOperation(boolean, Set<? extends FlowRule>, DeviceId) - Constructor for class org.onosproject.net.flow.CompletedBatchOperation
-
Creates a new batch completion result.
- ComponentConfigCommand - Class in org.onosproject.cli.cfg
-
Manages component configuration.
- ComponentConfigCommand() - Constructor for class org.onosproject.cli.cfg.ComponentConfigCommand
- ComponentConfigCommandCompleter - Class in org.onosproject.cli.cfg
-
Component configuration command completer.
- ComponentConfigCommandCompleter() - Constructor for class org.onosproject.cli.cfg.ComponentConfigCommandCompleter
- ComponentConfigEvent - Class in org.onosproject.cfg
-
Describes a component configuration event.
- ComponentConfigEvent(ComponentConfigEvent.Type, String, String, String) - Constructor for class org.onosproject.cfg.ComponentConfigEvent
-
Creates an event of a given type and for the specified app and the current time.
- ComponentConfigEvent.Type - Enum in org.onosproject.cfg
- ComponentConfigService - Interface in org.onosproject.cfg
-
Service for tracking system-wide configurations for various software components.
- ComponentConfigStore - Interface in org.onosproject.cfg
-
Service for storing and distributing system-wide configurations for various software components.
- ComponentConfigStoreDelegate - Interface in org.onosproject.cfg
-
Configuration property store delegate abstraction.
- ComponentNameCompleter - Class in org.onosproject.cli.cfg
-
Component name completer.
- ComponentNameCompleter() - Constructor for class org.onosproject.cli.cfg.ComponentNameCompleter
- ComponentPropertyNameCompleter - Class in org.onosproject.cli.cfg
-
Component property name completer.
- ComponentPropertyNameCompleter() - Constructor for class org.onosproject.cli.cfg.ComponentPropertyNameCompleter
- ComponentService - Interface in org.onosproject.component
-
Service for managing the components in the system.
- ComponentsMonitorService - Interface in org.onosproject.cluster
-
Monitors the status of OSGi components.
- compute(String, BiFunction<? super String, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.onosproject.store.service.ConsistentMap
-
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
- compute(K, BiFunction<K, V, V>) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
-
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
- computeBroadcastAddress(IpAddress, IpPrefix) - Static method in class org.onosproject.net.host.InterfaceIpAddress
-
Compute the IP broadcast address.
- computeCost() - Method in class org.onosproject.common.DefaultTopology
- computeCost() - Method in interface org.onosproject.net.topology.Topology
-
Returns the time, specified in system nanos of how long the topology took to compute.
- computeIf(String, Predicate<? super V>, BiFunction<? super String, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- computeIf(K, Predicate<? super V>, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- computeIf(K, Predicate<? super V>, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
If the value for the specified key satisfies a condition, attempts to compute a new mapping given the key and its current mapped value.
- computeIf(K, Predicate<? super V>, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.onosproject.store.service.ConsistentMap
-
If the value for the specified key satisfies a condition, attempts to compute a new mapping given the key and its current mapped value.
- computeIfAbsent(String, Function<? super String, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
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.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface org.onosproject.store.service.ConsistentMap
-
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(String, BiFunction<? super String, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
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.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.onosproject.store.service.ConsistentMap
-
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.
- computeSynthLinks() - Method in class org.onosproject.ui.model.topo.UiTopology
-
Uses the device-device links and data about the regions to compute the set of synthetic links that are required per region.
- ConcurrentModification() - Constructor for exception org.onosproject.store.service.ConsistentMapException.ConcurrentModification
- ConcurrentModification() - Constructor for exception org.onosproject.store.service.StorageException.ConcurrentModification
- ConcurrentModification() - Constructor for exception org.onosproject.store.service.TransactionException.ConcurrentModification
- ConcurrentModification(String) - Constructor for exception org.onosproject.store.service.ConsistentMapException.ConcurrentModification
- conditionalRemove(E, Predicate<E>) - Method in class org.onlab.util.ExtendedSet
-
Removes the entry if the supplied predicate evaluates to true.
- conditions() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
- conditions() - Method in interface org.onosproject.net.flowobjective.FilteringObjective
-
The set of conditions the filter must provision at the device.
- CONFIDENTIALITY_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
- config() - Method in class org.onosproject.net.config.NetworkConfigEvent
-
Returns current config.
- Config<S> - Class in org.onosproject.net.config
-
Base abstraction of a configuration facade for a specific subject.
- Config() - Constructor for class org.onosproject.net.config.Config
- CONFIG_ADDED - org.onosproject.net.config.NetworkConfigEvent.Type
-
Signifies that network configuration was added.
- CONFIG_CLASS - Static variable in interface org.onosproject.routing.RoutingService
- CONFIG_EVENT - org.onosproject.security.AppPermission.Type
- CONFIG_KEY - Static variable in class org.onosproject.net.behaviour.protection.ProtectionConfig
-
"protection" : a netcfg ConfigKey for
ProtectionConfig
. - CONFIG_KEY - Static variable in class org.onosproject.net.config.basics.BandwidthCapacity
-
netcfg ConfigKey for
BandwidthCapacity
. - CONFIG_KEY - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
-
Configuration key for
DeviceInjectionConfig
. - CONFIG_KEY - Static variable in class org.onosproject.net.config.basics.DeviceAnnotationConfig
-
"annotations" : a netcfg ConfigKey for
DeviceAnnotationConfig
. - CONFIG_KEY - Static variable in class org.onosproject.net.config.basics.HostAnnotationConfig
-
"annotations" : a netcfg ConfigKey for
HostAnnotationConfig
. - CONFIG_KEY - Static variable in class org.onosproject.net.config.basics.PortAnnotationConfig
-
"annotations" : a netcfg ConfigKey for
PortAnnotationConfig
. - CONFIG_KEY - Static variable in class org.onosproject.net.config.inject.DeviceInjectionConfig
-
Configuration key for
DeviceInjectionConfig
. - CONFIG_READ - org.onosproject.security.AppPermission.Type
- CONFIG_REGISTERED - org.onosproject.net.config.NetworkConfigEvent.Type
-
Signifies that a network configuration was registered.
- CONFIG_REMOVED - org.onosproject.net.config.NetworkConfigEvent.Type
-
Signifies that network configuration was removed.
- CONFIG_UNREGISTERED - org.onosproject.net.config.NetworkConfigEvent.Type
-
Signifies that a network configuration was unregistered.
- CONFIG_UPDATED - org.onosproject.net.config.NetworkConfigEvent.Type
-
Signifies that network configuration was updated.
- CONFIG_WRITE - org.onosproject.security.AppPermission.Type
- Config.FieldPresence - Enum in org.onosproject.net.config
-
Indicator of whether a configuration JSON field is required.
- ConfigApplyDelegate - Interface in org.onosproject.net.config
-
Delegate for notification when configuration changes have been applied.
- configClass() - Method in class org.onosproject.net.config.ConfigFactory
-
Returns the class of the configuration which this factory generates.
- configClass() - Method in class org.onosproject.net.config.NetworkConfigEvent
-
Returns the class of configuration that has been changed.
- ConfigException - Exception in org.onosproject.net.config
-
Signals that an error was encountered while reading/writing configuration.
- ConfigException(String) - Constructor for exception org.onosproject.net.config.ConfigException
-
Constructs a new ConfigException with the given message.
- ConfigException(String, Throwable) - Constructor for exception org.onosproject.net.config.ConfigException
-
Constructs a new ConfigException with the given message and cause.
- ConfigFactory<S,C extends Config<S>> - Class in org.onosproject.net.config
-
Base abstract factory for creating configurations for the specified subject type.
- ConfigFactory(SubjectFactory<S>, Class<C>, String) - Constructor for class org.onosproject.net.config.ConfigFactory
-
Creates a new configuration factory for the specified class of subjects capable of generating the configurations of the specified class.
- ConfigFactory(SubjectFactory<S>, Class<C>, String, boolean) - Constructor for class org.onosproject.net.config.ConfigFactory
-
Creates a new configuration factory for the specified class of subjects capable of generating the configurations of the specified class.
- ConfigGetter - Interface in org.onosproject.net.behaviour
-
Behaviour that gets the configuration of the specified type from the device.
- configKey() - Method in class org.onosproject.net.config.ConfigFactory
-
Returns the unique key (within subject class) of this configuration.
- configKey() - Method in exception org.onosproject.net.config.InvalidConfigException
-
Returns the config key of the config.
- ConfigKeyCompleter - Class in org.onosproject.cli.cfg
-
Network configuration config key completer.
- ConfigKeyCompleter() - Constructor for class org.onosproject.cli.cfg.ConfigKeyCompleter
- ConfigOperator - Interface in org.onosproject.net.config
-
An interface signifying a class that implements network configuration information from multiple sources.
- ConfigProperty - Class in org.onosproject.cfg
-
Component configuration property.
- ConfigProperty.Type - Enum in org.onosproject.cfg
-
Representation of the type of property value.
- ConfigSetter - Interface in org.onosproject.net.behaviour
-
Behaviour that sets the configuration to a device.
- configured() - Method in class org.onosproject.net.DefaultHost
- configured() - Method in interface org.onosproject.net.Host
-
Returns true if configured by NetworkConfiguration.
- configured() - Method in class org.onosproject.net.host.DefaultHostDescription
- configured() - Method in interface org.onosproject.net.host.HostDescription
-
Returns true if configured by NetworkConfiguration.
- configureDevice(IpAddress, int, String) - Method in interface org.onosproject.alarm.DeviceAlarmConfig
-
Configures the device to send alarms to a particular Ip and port combination.
- ConfigureLinkCommand - Class in org.onosproject.cli.net
-
Add Link configuration.
- ConfigureLinkCommand() - Constructor for class org.onosproject.cli.net.ConfigureLinkCommand
- configureUri(URI) - Method in interface org.onosproject.net.behaviour.SoftwareUpgrade
-
Configures the uri from where the upgrade will be pulled.
- CONFIRM - org.onlab.packet.DHCP6.MsgType
- connect() - Method in interface org.onosproject.net.driver.DeviceConnect
-
Connects to the device, for example by opening the transport session that will be later used to send control messages.
- CONNECT_POINT - Static variable in class org.onosproject.routing.config.BgpConfig
- CONNECT_POINT_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
- CONNECT_POINT_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
-
Connect point subject factory.
- connection() - Method in class org.onosproject.ui.UiMessageHandler
-
Returns the user interface connection with which this handler was primed.
- ConnectivityIntent - Class in org.onosproject.net.intent
-
Abstraction of connectivity intent for traffic matching some criteria.
- ConnectivityIntent() - Constructor for class org.onosproject.net.intent.ConnectivityIntent
-
Constructor for serializer.
- ConnectivityIntent(ApplicationId, Key, Collection<NetworkResource>, TrafficSelector, TrafficTreatment, List<Constraint>, int, ResourceGroup) - Constructor for class org.onosproject.net.intent.ConnectivityIntent
-
Creates a connectivity intent that matches on the specified selector and applies the specified treatment.
- ConnectivityIntent.Builder - Class in org.onosproject.net.intent
-
Abstract builder for connectivity intents.
- ConnectivityIntentCommand - Class in org.onosproject.cli.net
-
Base class for command line operations for connectivity based intents.
- ConnectivityIntentCommand() - Constructor for class org.onosproject.cli.net.ConnectivityIntentCommand
- connectPoint() - Method in class org.onlab.packet.dhcp.CircuitId
-
Gets the connect point of circuit id.
- connectPoint() - Method in class org.onosproject.net.behaviour.trafficcontrol.PolicingResource
-
Returns the connect point of this resource.
- connectPoint() - Method in class org.onosproject.net.FilteredConnectPoint
-
Returns the connection point.
- connectPoint() - Method in interface org.onosproject.net.host.HostProbe
-
Gets connect point of this entry.
- connectPoint() - Method in class org.onosproject.net.intf.Interface
-
Retrieves the connection point that this interface maps to.
- connectPoint() - Method in class org.onosproject.net.statistic.FlowEntryWithLoad
-
Returns connect point.
- connectPoint() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
-
Returns connect point.
- connectPoint() - Method in class org.onosproject.net.statistic.TypedFlowEntryWithLoad
- connectPoint() - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
- ConnectPoint - Class in org.onosproject.net
-
Abstraction of a network connection point expressed as a pair of the network element identifier and port number.
- ConnectPoint(ElementId, PortNumber) - Constructor for class org.onosproject.net.ConnectPoint
-
Creates a new connection point.
- ConnectPointCompleter - Class in org.onosproject.cli.net
-
ConnectPoint completer.
- ConnectPointCompleter() - Constructor for class org.onosproject.cli.net.ConnectPointCompleter
- ConnectPointFormatter - Class in org.onosproject.ui.table.cell
-
Formats a connect point as "(element-id)/(port)".
- ConnectPointSerializer - Class in org.onosproject.store.serializers
-
Kryo Serializer for
ConnectPointSerializer
. - ConnectPointSerializer() - Constructor for class org.onosproject.store.serializers.ConnectPointSerializer
-
Creates
ConnectPointSerializer
serializer instance. - CONSISTENT_MAP - org.onosproject.store.service.DistributedPrimitive.Type
-
Map with strong consistency semantics.
- CONSISTENT_MULTIMAP - org.onosproject.store.service.DistributedPrimitive.Type
-
Consistent Multimap.
- CONSISTENT_TREEMAP - org.onosproject.store.service.DistributedPrimitive.Type
-
Tree map.
- ConsistentMap<K,V> - Interface in org.onosproject.store.service
-
ConsistentMap
provides the same functionality asAsyncConsistentMap
with the only difference that all its methods block until the corresponding operation completes. - ConsistentMapBackedJavaMap<K,V> - Class in org.onosproject.store.primitives
-
Standard java
Map
backed by aConsistentMap
. - ConsistentMapBackedJavaMap(ConsistentMap<K, V>) - Constructor for class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- consistentMapBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new ConsistentMapBuilder.
- consistentMapBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new ConsistentMapBuilder.
- ConsistentMapBuilder<K,V> - Class in org.onosproject.store.service
-
Builder for
ConsistentMap
instances. - ConsistentMapBuilder() - Constructor for class org.onosproject.store.service.ConsistentMapBuilder
- ConsistentMapException - Exception in org.onosproject.store.service
-
Top level exception for ConsistentMap failures.
- ConsistentMapException() - Constructor for exception org.onosproject.store.service.ConsistentMapException
- ConsistentMapException(String) - Constructor for exception org.onosproject.store.service.ConsistentMapException
- ConsistentMapException(Throwable) - Constructor for exception org.onosproject.store.service.ConsistentMapException
- ConsistentMapException.ConcurrentModification - Exception in org.onosproject.store.service
-
ConsistentMap update conflicts with an in flight transaction.
- ConsistentMapException.Interrupted - Exception in org.onosproject.store.service
-
ConsistentMap operation interrupted.
- ConsistentMapException.Timeout - Exception in org.onosproject.store.service
-
ConsistentMap operation timeout.
- ConsistentMapOptions<O extends ConsistentMapOptions<O,K,V>,K,V> - Class in org.onosproject.store.service
-
Builder for
ConsistentMap
instances. - ConsistentMapOptions() - Constructor for class org.onosproject.store.service.ConsistentMapOptions
- ConsistentMultimap<K,V> - Interface in org.onosproject.store.service
-
This provides a synchronous version of the functionality provided by
AsyncConsistentMultimap
. - consistentMultimapBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new
AsyncConsistentSetMultimapBuilder
. - consistentMultimapBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new
AsyncConsistentSetMultimapBuilder
. - ConsistentMultimapBuilder<K,V> - Class in org.onosproject.store.service
-
A builder class for
AsyncConsistentMultimap
. - ConsistentMultimapBuilder() - Constructor for class org.onosproject.store.service.ConsistentMultimapBuilder
- ConsistentMultimapOptions<O extends ConsistentMultimapOptions<O,K,V>,K,V> - Class in org.onosproject.store.service
-
A builder class for
AsyncConsistentMultimap
. - ConsistentMultimapOptions() - Constructor for class org.onosproject.store.service.ConsistentMultimapOptions
- ConsistentTreeMap<V> - Interface in org.onosproject.store.service
-
Tree map interface counterpart to
AsyncConsistentTreeMap
. - consistentTreeMapBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
-
Creates a new
AsyncConsistentTreeMapBuilder
. - consistentTreeMapBuilder() - Method in interface org.onosproject.store.service.StorageService
-
Creates a new
AsyncConsistentTreeMapBuilder
. - ConsistentTreeMapBuilder<V> - Class in org.onosproject.store.service
-
Builder for
ConsistentTreeMap
. - ConsistentTreeMapBuilder() - Constructor for class org.onosproject.store.service.ConsistentTreeMapBuilder
- ConsistentTreeMapOptions<O extends ConsistentTreeMapOptions<O,V>,V> - Class in org.onosproject.store.service
-
Builder for
ConsistentTreeMap
. - ConsistentTreeMapOptions() - Constructor for class org.onosproject.store.service.ConsistentTreeMapOptions
- constDefaultAction() - Method in interface org.onosproject.net.pi.model.PiTableModel
-
Returns the model of the constant default action associated with this table, if any.
- Constraint - Interface in org.onosproject.net.intent
-
Representation of a connectivity constraint capable of evaluating a link and determining the cost of traversing that link in the context of this constraint.
- constraints - Variable in class org.onosproject.net.domain.DomainIntent.Builder
- constraints - Variable in class org.onosproject.net.intent.ConnectivityIntent.Builder
- constraints() - Method in class org.onosproject.net.domain.DomainIntent
-
Returns the set of connectivity constraints.
- constraints() - Method in class org.onosproject.net.intent.ConnectivityIntent
-
Returns the set of connectivity constraints.
- constraints(List<Constraint>) - Method in class org.onosproject.net.domain.DomainIntent.Builder
-
Sets the constraints for the intent that will be built.
- constraints(List<Constraint>) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.ConnectivityIntent.Builder
-
Sets the constraints for the intent that will be built.
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.PathIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
- constraints(List<Constraint>) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
- consumeAlarms() - Method in interface org.onosproject.alarm.AlarmConsumer
-
Returns the list of active alarms consumed from the device.
- consumerClass() - Method in class org.onosproject.net.resource.ResourceConsumerId
-
Returns class name of the consumer.
- consumerId() - Method in class org.onosproject.net.intent.IntentId
- consumerId() - Method in class org.onosproject.net.intent.Key
- consumerId() - Method in class org.onosproject.net.resource.ResourceAllocation
-
Returns ID of the consumer of this resource.
- consumerId() - Method in interface org.onosproject.net.resource.ResourceConsumer
-
Returns ID of this consumer.
- consumerId() - Method in class org.onosproject.net.ResourceGroup
- contains(E) - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Returns if this set contains the specified element.
- contains(E) - Method in interface org.onosproject.store.service.TransactionalSet
-
Returns true if this set contains the specified element.
- contains(Object) - Method in class org.onlab.util.ExtendedSet
- contains(Object) - Method in class org.onlab.util.UnmodifiableDeque
- contains(Object) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
- contains(IpAddress) - Method in class org.onlab.packet.IpPrefix
-
Determines whether a given IP address is contained within this prefix.
- contains(IpPrefix) - Method in class org.onlab.packet.IpPrefix
-
Determines whether a given IP prefix is contained within this prefix.
- containsAll(Collection<?>) - Method in class org.onlab.util.ExtendedSet
- containsAll(Collection<?>) - Method in class org.onlab.util.UnmodifiableDeque
- containsAll(Collection<?>) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
- containsAll(Collection<? extends E>) - Method in interface org.onosproject.store.service.AsyncDistributedSet
-
Returns if this set contains all the elements in specified collection.
- containsEntry(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
- containsEntry(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Returns true if this map contains at least one key-value pair with key and value specified.
- containsEntry(K, V) - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Returns true if this map contains at least one key-value pair with key and value specified.
- containsKey(Object) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- containsKey(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- containsKey(K) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- containsKey(K) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
- containsKey(K) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Returns true if this map contains a mapping for the specified key.
- containsKey(K) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Returns true if there is at lease one key-value pair with a key equal to key.
- containsKey(K) - Method in interface org.onosproject.store.service.ConsistentMap
-
Returns true if this map contains a mapping for the specified key.
- containsKey(K) - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Returns true if there is at lease one key-value pair with a key equal to key.
- containsKey(K) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
-
Returns true if the map contains a mapping for the specified key.
- containsKey(K) - Method in interface org.onosproject.store.service.TransactionalMap
-
Returns true if this map contains a mapping for the specified key.
- containsValue(Object) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
- containsValue(V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
- containsValue(V) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
- containsValue(V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
- containsValue(V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
-
Returns true if this map contains the specified value.
- containsValue(V) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
-
Returns true if this map contains at lease one key-value pair with a value equal to value.
- containsValue(V) - Method in interface org.onosproject.store.service.ConsistentMap
-
Returns true if this map contains the specified value.
- containsValue(V) - Method in interface org.onosproject.store.service.ConsistentMultimap
-
Returns true if this map contains at lease one key-value pair with a value equal to value.
- containsValue(V) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
-
Returns true if the map contains a mapping from any key to the specified value.
- context() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
- context() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
- context() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
- context() - Method in interface org.onosproject.net.flowobjective.Objective
-
Obtains an optional context.
- context() - Method in class org.onosproject.net.meter.DefaultMeterRequest
- context() - Method in interface org.onosproject.net.meter.MeterRequest
-
Returns the callback context for this meter.
- Context(Timer.Context, String) - Constructor for class org.onosproject.utils.MeteringAgent.Context
-
Constructs Context.
- CONTINENT - org.onosproject.net.region.Region.Type
-
Region represents an entire continent.
- continuous(DeviceId, Class<?>) - Static method in class org.onosproject.net.resource.Resources
-
Create a factory for continuous-type with the specified device ID and type.
- continuous(DeviceId, Object...) - Static method in class org.onosproject.net.resource.Resources
-
Create a factory for continuous-type with the specified device ID and components.
- continuous(DeviceId, PortNumber, Class<?>) - Static method in class org.onosproject.net.resource.Resources
-
Create a factory for continuous-type with the specified device ID, port number and type.
- continuous(DeviceId, PortNumber, Object...) - Static method in class org.onosproject.net.resource.Resources
-
Create a factory for continuous-type with the specified device ID and components.
- ContinuousFactory - Class in org.onosproject.net.resource
-
Factory class for continuous-type resource related instances.
- ContinuousResource - Class in org.onosproject.net.resource
-
Represents a resource path which specifies a resource which can be measured as continuous value.
- ContinuousResourceId - Class in org.onosproject.net.resource
-
ResourceId for
ContinuousResource
. - CONTROL - org.onosproject.net.packet.PacketPriority
-
High priority for control traffic.
- CONTROL_MESSAGE - org.onosproject.cpman.ControlResource.Type
- CONTROL_MESSAGE_METRICS - Static variable in class org.onosproject.cpman.ControlResource
- CONTROL_PLANE - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
-
Count the received control plane packets.
- CONTROLLER - org.onosproject.net.Device.Type
- CONTROLLER - org.onosproject.net.PortNumber.Logical
- CONTROLLER - Static variable in class org.onosproject.net.meter.MeterId
-
Meter for controller connection.
- CONTROLLER - Static variable in class org.onosproject.net.PortNumber
- ControllerConfig - Interface in org.onosproject.net.behaviour
-
Device behaviour to obtain, set and remove controllers at the device.
- ControllerInfo - Class in org.onosproject.net.behaviour
-
Represents information for a device to connect to a controller.
- ControllerInfo(String) - Constructor for class org.onosproject.net.behaviour.ControllerInfo
-
Deprecated.in Hummingbird (1.7.0)
- ControllerInfo(IpAddress, int, String) - Constructor for class org.onosproject.net.behaviour.ControllerInfo
-
Information for contacting the controller.
- ControllerInfo(IpAddress, int, String, Annotations) - Constructor for class org.onosproject.net.behaviour.ControllerInfo
-
Information for contacting the controller.
- ControllerNode - Interface in org.onosproject.cluster
-
Represents a controller instance as a member in a cluster.
- ControllerNode.State - Enum in org.onosproject.cluster
-
Represents the operational state of the instance.
- ControllerNodeToNodeId - Class in org.onosproject.cluster
-
Function to convert ControllerNode to NodeId.
- ControllerNodeToNodeId() - Constructor for class org.onosproject.cluster.ControllerNodeToNodeId
- controllers() - Method in interface org.onosproject.net.behaviour.BridgeDescription
-
Returns OpenFlow controllers of the bridge.
- controllers() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
- controllers(List<ControllerInfo>) - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
-
Returns bridge description builder with given controllers.
- controllers(List<ControllerInfo>) - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
- ControlLoad - Interface in org.onosproject.cpman
-
Data repository for control plane load information.
- ControlLoadSnapshot - Class in org.onosproject.cpman
-
A container class that is used to wrap the control metric response.
- ControlLoadSnapshot(long, long, long) - Constructor for class org.onosproject.cpman.ControlLoadSnapshot
-
Instantiates a new control metric response with given latest, average, time.
- ControlLoadSnapshot(long, long, long, long[]) - Constructor for class org.onosproject.cpman.ControlLoadSnapshot
-
Instantiates a new control metric response with given latest, average, time, recent values.
- ControlMessage - Interface in org.onosproject.cpman
-
Abstraction of control message.
- ControlMessage.Type - Enum in org.onosproject.cpman
- ControlMessageAdminService - Interface in org.onosproject.cpman.message
-
Service for administering the control message monitoring.
- ControlMessageEvent - Class in org.onosproject.cpman.message
-
Describes control message event.
- ControlMessageEvent(ControlMessageEvent.Type, Set<ControlMessage>) - Constructor for class org.onosproject.cpman.message.ControlMessageEvent
-
Creates an event of given type and the current time.
- ControlMessageEvent.Type - Enum in org.onosproject.cpman.message
-
Type of control message events.
- ControlMessageListener - Interface in org.onosproject.cpman.message
-
Entity capable of receiving control message related event.
- ControlMessageProvider - Interface in org.onosproject.cpman.message
-
Abstraction of a control message provider.
- ControlMessageProviderRegistry - Interface in org.onosproject.cpman.message
-
Abstraction of a control message provider registry.
- ControlMessageProviderService - Interface in org.onosproject.cpman.message
-
Service through which control message providers can inject control message stats into the core.
- ControlMessageService - Interface in org.onosproject.cpman.message
-
Service for obtaining control message statistic information.
- ControlMessageStore - Interface in org.onosproject.cpman.message
-
Manages inventory of control message.
- ControlMessageStoreDelegate - Interface in org.onosproject.cpman.message
-
Control message store delegate abstraction.
- ControlMetric - Class in org.onosproject.cpman
-
Include various control plane metrics.
- ControlMetric(ControlMetricType, MetricValue) - Constructor for class org.onosproject.cpman.ControlMetric
-
Constructs a control metric using the given control metric type and metric value.
- ControlMetricsRequest - Class in org.onosproject.cpman
-
A container class that is used to request control metric of remote node.
- ControlMetricsRequest(ControlMetricType, int, TimeUnit, String) - Constructor for class org.onosproject.cpman.ControlMetricsRequest
-
Instantiates a new control metric request of the control metric type and resource name with the given projected time range.
- ControlMetricsRequest(ControlMetricType, int, TimeUnit, Optional<DeviceId>) - Constructor for class org.onosproject.cpman.ControlMetricsRequest
-
Instantiates a new control metric request of the control metric type and device identifier with the given projected time range.
- ControlMetricsRequest(ControlMetricType, String) - Constructor for class org.onosproject.cpman.ControlMetricsRequest
-
Instantiates a new control metric request of the control metric type and resource name.
- ControlMetricsRequest(ControlMetricType, Optional<DeviceId>) - Constructor for class org.onosproject.cpman.ControlMetricsRequest
-
Instantiates a new control metric request of the control metric type and device identifier.
- ControlMetricType - Enum in org.onosproject.cpman
-
A set of metric type used in control plane.
- controlPlaneConnectPoint() - Method in class org.onosproject.routing.config.RoutersConfig.Router
-
Returns the routing control plane connect point.
- controlPlaneConnectPoint() - Method in class org.onosproject.routing.InterfaceProvisionRequest
-
Retrieves the router's control plane connect point.
- controlPlaneConnectPoint() - Method in class org.onosproject.routing.RouterInfo
-
Returns the control plane connect point.
- ControlPlaneMonitorService - Interface in org.onosproject.cpman
-
Control Plane Statistics Service Interface.
- ControlPlaneService - Interface in org.onosproject.cpman
-
Control Plane Service interface.
- controlProtocols() - Method in interface org.onosproject.net.behaviour.BridgeDescription
-
Returns list of Control Protocol Versions supported on device.
- controlProtocols() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
- controlProtocols(List<ControlProtocolVersion>) - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
-
Returns bridge description builder with given control protocol versions.
- controlProtocols(List<ControlProtocolVersion>) - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
- ControlProtocolVersion - Enum in org.onosproject.net.behaviour
- ControlResource - Class in org.onosproject.cpman
-
A set of resource type used in control plane.
- ControlResource.Type - Enum in org.onosproject.cpman
-
Control resource type.
- ControlResourceRequest - Class in org.onosproject.cpman
-
A container class that is used to request available resource of remote node.
- ControlResourceRequest(ControlResource.Type) - Constructor for class org.onosproject.cpman.ControlResourceRequest
-
Instantiates a new control resource request of the control resource type.
- cookie() - Method in class org.onosproject.net.packet.DefaultInboundPacket
- cookie() - Method in interface org.onosproject.net.packet.InboundPacket
-
Returns the cookie in the packet in message.
- cookie() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
-
Returns the cookie of this table entry.
- CoordinationService - Interface in org.onosproject.store.service
-
Cross-version storage/coordination service.
- COPPER - org.onosproject.net.Port.Type
-
Signifies copper-based connectivity.
- copy() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
- copy() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
- copy() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
- copy() - Method in interface org.onosproject.net.flowobjective.FilteringObjective
-
Returns a new builder set to create a copy of this objective.
- copy() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective
-
Returns a new builder set to create a copy of this objective.
- copy() - Method in interface org.onosproject.net.flowobjective.NextObjective
-
Returns a new builder set to create a copy of this objective.
- copy() - Method in interface org.onosproject.net.flowobjective.Objective
-
Returns a new builder set to create a copy of this objective.
- copy(IntentData) - Static method in class org.onosproject.net.intent.IntentData
-
Creates a copy of given IntentData.
- copy(IntentData, Timestamp) - Static method in class org.onosproject.net.intent.IntentData
-
Creates a copy of given IntentData, and update request version.
- copy(T) - Method in interface org.onosproject.store.serializers.StoreSerializer
-
Deprecated.Returns a copy of the specfied object.
- copy(T) - Method in interface org.onosproject.store.service.Serializer
-
Copies the specified object.
- copyDirectory(File, File) - Static method in class org.onlab.util.Tools
-
Copies the specified directory path. Use with great caution since no attempt is made to check for symbolic links, which could result in copy of unintended files.
- copyDirectory(String, String) - Static method in class org.onlab.util.Tools
-
Copies the specified directory path. Use with great caution since no attempt is made to check for symbolic links, which could result in copy of unintended files.
- copyFrom(byte) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new byte sequence of 1 byte containing the given value.
- copyFrom(byte[]) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new immutable byte sequence with the same content and order of the passed byte array.
- copyFrom(byte[], int, int) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new immutable byte sequence with the same content and order of the passed byte array, from/to the given indexes (inclusive).
- copyFrom(int) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new byte sequence of 4 bytes containing the given int value.
- copyFrom(long) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new byte sequence of 8 bytes containing the given long value.
- copyFrom(short) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new byte sequence of 2 bytes containing the given short value.
- copyFrom(ByteBuffer) - Static method in class org.onlab.util.ImmutableByteSequence
-
Creates a new immutable byte sequence copying bytes from the given ByteBuffer
ByteBuffer
. - copyFrom(ProtectedTransportEndpointState) - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState.Builder
-
Copies all the fields from
src
. - copyFrom(TransportEndpointDescription) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription.Builder
-
Copies all the fields from
src
. - copyFrom(TransportEndpointState) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
-
Copies all the fields from
src
. - copyOf(byte[]) - Static method in class org.onlab.util.Tools
-
Returns a copy of the input byte array.
- copyReplacingAnnotation(DeviceDescription, SparseAnnotations) - Static method in class org.onosproject.net.device.DefaultDeviceDescription
-
Creates a device description using the supplied information.
- copyReplacingAnnotation(HostDescription, SparseAnnotations) - Static method in class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- copyTtlIn() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- copyTtlIn() - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates a L3 copy TTL to inner header modification.
- copyTtlIn() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Copy the TTL to inner protocol layer.
- copyTtlOut() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- copyTtlOut() - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates a L3 copy TTL to outer header modification.
- copyTtlOut() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Copy the TTL to outer protocol layer.
- CORE_APP_NAME - Static variable in interface org.onosproject.core.CoreService
-
Name of the core "application".
- CORE_PROVIDER_ID - Static variable in interface org.onosproject.core.CoreService
-
Identifier of the core "provider".
- CoreButtons() - Constructor for class org.onosproject.ui.topo.TopoConstants.CoreButtons
- coreCount() - Method in interface org.onosproject.cpman.SystemInfo
-
Returns number of CPU cores.
- coreService - Variable in class org.onosproject.cli.CliComponent
- CoreService - Interface in org.onosproject.core
-
Service for interacting with the core system of the controller.
- corrupt(IntentData) - Static method in class org.onosproject.net.intent.IntentData
-
Creates a copy of IntentData in corrupt state, incrementing error count.
- CORRUPT - org.onosproject.net.intent.IntentEvent.Type
-
Signifies that an intent has failed installation or withdrawal, but still hold some or all of its resources.
- CORRUPT - org.onosproject.net.intent.IntentState
-
Signifies that an intent has failed either installation or withdrawal, and still hold some or all of its resources.
- cost() - Method in class org.onlab.graph.DefaultMutablePath
- cost() - Method in class org.onlab.graph.DefaultPath
- cost() - Method in class org.onlab.graph.DisjointPathPair
- cost() - Method in interface org.onlab.graph.Path
-
Returns the total cost of the path as a weight object.
- cost() - Method in class org.onosproject.net.DefaultDisjointPath
- cost() - Method in class org.onosproject.net.DefaultPath
- cost() - Method in class org.onosproject.net.intent.LinkCollectionIntent
-
Returns the cost of the links of this intent.
- cost() - Method in interface org.onosproject.net.Path
-
Deprecated.in Junco (1.9.0), use weight() instead
- cost(double) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
-
Sets the cost for the links of the Intent.
- cost(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
- cost(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.BooleanConstraint
-
Evaluates the specified link and provides the cost for its traversal.
- cost(Link, ResourceContext) - Method in interface org.onosproject.net.intent.Constraint
-
Evaluates the specified link and provides the cost for its traversal.
- cost(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.LatencyConstraint
- cost(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.MarkerConstraint
- cost(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.PathViabilityConstraint
- costs - Variable in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
- costs() - Method in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
- costs() - Method in interface org.onlab.graph.GraphPathSearch.Result
-
Return a bindings of each vertex to its cost in the path.
- count() - Method in interface org.onosproject.cpman.ControlMessage
-
Returns the latest control message packet count.
- count() - Method in class org.onosproject.cpman.DefaultControlMessage
- count(long) - Method in class org.onosproject.cpman.MetricValue.Builder
-
Sets count value.
- countDown() - Method in class org.onlab.util.CountDownCompleter
-
Records a single completion.
- CountDownCompleter<T> - Class in org.onlab.util
-
A synchronization utility that defers invocation of a
consumer
callback until a set number of actions tracked by along
counter complete. - CountDownCompleter(T, long, Consumer<T>) - Constructor for class org.onlab.util.CountDownCompleter
-
Constructor.
- counter() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
-
Returns the data of the counter cell associated with this table entry.
- counter(PiCounterId) - Method in interface org.onosproject.net.pi.model.PiPipelineModel
-
Returns the counter model associated with the given ID, if present.
- Counter - Class in org.onlab.util
-
Counting mechanism capable of tracking occurrences and rates.
- Counter() - Constructor for class org.onlab.util.Counter
-
Creates a new counter.
- Counter(long, long, long) - Constructor for class org.onlab.util.Counter
-
Creates a new counter in a specific state.
- COUNTER - org.onosproject.store.service.DistributedPrimitive.Type
-
Atomic counter.
- COUNTER_CELL - org.onosproject.net.pi.runtime.PiEntityType
-
Counter cell.
- COUNTER_MAP - org.onosproject.store.service.DistributedPrimitive.Type
-
Atomic counter map.
- CounterCommand - Class in org.onosproject.cli.net
-
Command to display the current value of a atomic counter.
- CounterCommand() - Constructor for class org.onosproject.cli.net.CounterCommand
- counterId() - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
-
Returns the identifier of the counter instance where this cell is contained.
- counters() - Method in interface org.onosproject.net.pi.model.PiPipelineModel
-
Returns all counter models defined by this pipeline model.
- counters() - Method in interface org.onosproject.net.pi.model.PiTableModel
-
Returns a collection of direct counters associated to this table.
- CountersListCommand - Class in org.onosproject.cli.net
-
Command to list the various counters in the system.
- CountersListCommand() - Constructor for class org.onosproject.cli.net.CountersListCommand
- counterType() - Method in interface org.onosproject.net.pi.model.PiCounterModel
-
Returns the type of counter.
- counterType() - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
-
Returns the type of the counter identified.
- COUNTRY - org.onosproject.net.region.Region.Type
-
Region represents an entire country.
- CPU - org.onosproject.cpman.ControlResource.Type
- CPU_IDLE_TIME - org.onosproject.cpman.ControlMetricType
- CPU_LOAD - org.onosproject.cpman.ControlMetricType
- CPU_METRICS - Static variable in class org.onosproject.cpman.ControlResource
- CPU_PORT_TXT - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
-
CPU port file in UTF 8 encoding.
- CPU_SPEED - org.onosproject.cpman.ControlMetricType
- cpuCount() - Method in interface org.onosproject.cpman.SystemInfo
-
Returns number of CPUs.
- cpuSpeed() - Method in interface org.onosproject.cpman.SystemInfo
-
Returns CPU speed in MHz.
- cpuSpeed(int) - Method in interface org.onosproject.cpman.SystemInfo.Builder
-
Sets CPU speed.
- create() - Method in class org.onlab.util.KryoNamespace
-
Creates a Kryo instance.
- create(short, short, ByteBuffer) - Static method in class org.onlab.packet.pim.PIMHelloOption
-
Creates a new PIM Hello option with the specified values.
- create(InputStream) - Method in interface org.onosproject.app.ApplicationStore
-
Creates the application from the specified application descriptor input stream.
- create(InputStream) - Method in class org.onosproject.store.app.DistributedApplicationStore
- create(DeviceService) - Static method in class org.onosproject.routing.AsyncDeviceFetcher
-
Creates a device fetcher based on the device service.
- create(LinkKey, Link) - Method in class org.onosproject.ui.topo.BaseLinkMap
- create(LinkKey, Link) - Method in class org.onosproject.ui.topo.BiLinkMap
-
Creates a new instance of a bi-link.
- create(DocumentPath, V) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
- create(DocumentPath, V) - Method in interface org.onosproject.store.service.AsyncDocumentTree
-
Creates a document tree node if one does not exist already.
- create(DocumentPath, V) - Method in interface org.onosproject.store.service.DocumentTree
-
Creates a document tree node if one does not exist already.
- CREATE_NODE - org.onosproject.store.primitives.NodeUpdate.Type
-
Creates an entry if the current version matches specified version.
- createAddGroupOperation(GroupId, GroupDescription.Type, GroupBuckets) - Static method in class org.onosproject.net.group.GroupOperation
-
Creates ADD group operation object.
- createAllGroupBucket(TrafficTreatment) - Static method in class org.onosproject.net.group.DefaultGroupBucket
-
Creates all group bucket.
- createBehaviour(DriverData, Class<T>) - Method in class org.onosproject.net.driver.DefaultDriver
- createBehaviour(DriverData, Class<T>) - Method in interface org.onosproject.net.driver.Driver
-
Creates an instance of behaviour primed with the specified driver data.
- createBehaviour(DriverHandler, Class<T>) - Method in class org.onosproject.net.driver.DefaultDriver
- createBehaviour(DriverHandler, Class<T>) - Method in interface org.onosproject.net.driver.Driver
-
Creates an instance of behaviour primed with the specified driver handler.
- createChartModel() - Method in class org.onosproject.ui.chart.ChartRequestHandler
-
Creates the chart model using
ChartRequestHandler.getSeries()
to initialize it, ready to be populated. - createCloneGroupBucket(TrafficTreatment) - Static method in class org.onosproject.net.group.DefaultGroupBucket
-
Creates clone group bucket.
- createConfig() - Method in class org.onosproject.net.config.ConfigFactory
-
Creates a new but uninitialized configuration.
- createConfig(S, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigStore
-
Creates a new configuration of the given class for the specified subject.
- createCounter(MetricsComponent, MetricsFeature, String) - Method in class org.onlab.metrics.MetricsManager
-
Creates a Counter metric.
- createCounter(MetricsComponent, MetricsFeature, String) - Method in interface org.onlab.metrics.MetricsService
-
Creates a Counter metric.
- created() - Method in class org.onosproject.net.flow.DefaultFlowRule
-
Returns the wallclock time that the flow was created.
- CREATED - org.onosproject.alarm.AlarmEvent.Type
-
Individual alarm updated.
- CREATED - org.onosproject.net.pi.service.PiPipeconfDeviceMappingEvent.Type
-
Individual mapping pipeconf to device added.
- CREATED - org.onosproject.store.service.DocumentTreeEvent.Type
-
Signifies node being created.
- createDefaultOptions() - Method in class org.onlab.packet.pim.PIMHello
-
Create a PIM Hello packet with the most common hello options and default values.
- createDeleteGroupOperation(GroupId, GroupDescription.Type) - Static method in class org.onosproject.net.group.GroupOperation
-
Creates DELETE group operation object.
- createDeviceKeyUsingCommunityName(DeviceKeyId, String, String) - Static method in class org.onosproject.net.key.DeviceKey
-
Method to create a device key of type CommunityName.
- createDeviceKeyUsingSshKey(DeviceKeyId, String, String, String, String) - Static method in class org.onosproject.net.key.DeviceKey
-
Method to create a device key of type SSL_KEY.
- createDeviceKeyUsingUsernamePassword(DeviceKeyId, String, String, String) - Static method in class org.onosproject.net.key.DeviceKey
-
Method to create a device key of type USERNAME_PASSWORD.
- createDocFromMessage(InputStream) - Static method in class org.onosproject.alarm.XmlEventParser
-
Creates a document from the input stream message and returns the result.
- createEdgeLink(ConnectPoint, boolean) - Static method in class org.onosproject.net.DefaultEdgeLink
-
Creates a phantom edge link, to an unspecified end-station.
- createEdgeLink(Host, boolean) - Static method in class org.onosproject.net.DefaultEdgeLink
-
Creates a an edge link, to the specified end-station.
- createEdgeLinks(Host, boolean) - Static method in class org.onosproject.net.DefaultEdgeLink
-
Creates edge links, to the specified end-station.
- createFailedGroupOperation(GroupOperation, GroupOperation.GroupMsgErrorCode) - Static method in class org.onosproject.net.group.GroupOperation
-
Creates failure group operation object by setting failure code to inform the failure reason.
- createFailoverGroupBucket(TrafficTreatment, PortNumber, GroupId) - Static method in class org.onosproject.net.group.DefaultGroupBucket
-
Creates failover group bucket with watchport or watchgroup.
- createGenID(int) - Static method in class org.onlab.packet.pim.PIMHelloOption
-
Creates a new generation ID option with a particular generation ID.
- createGroup(GroupId) - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates a group instruction.
- createHandler(DeviceId, String...) - Method in interface org.onosproject.net.driver.DriverService
-
Creates a new driver handler for interacting with the specified device.
- createHistogram(MetricsComponent, MetricsFeature, String) - Method in class org.onlab.metrics.MetricsManager
-
Creates a Histogram metric.
- createHistogram(MetricsComponent, MetricsFeature, String) - Method in interface org.onlab.metrics.MetricsService
-
Creates a Histogram metric.
- createHoldTime(short) - Static method in class org.onlab.packet.pim.PIMHelloOption
-
Creates a new hold time option.
- createIndirectGroupBucket(TrafficTreatment) - Static method in class org.onosproject.net.group.DefaultGroupBucket
-
Creates indirect group bucket.
- createMeter(MetricsComponent, MetricsFeature, String) - Method in class org.onlab.metrics.MetricsManager
-
Creates a Meter metric.
- createMeter(MetricsComponent, MetricsFeature, String) - Method in interface org.onlab.metrics.MetricsService
-
Creates a Meter metric.
- createModifyGroupOperation(GroupId, GroupDescription.Type, GroupBuckets) - Static method in class org.onosproject.net.group.GroupOperation
-
Creates MODIFY group operation object.
- createNoAction() - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates a no action instruction.
- createOrUpdateBinding(DeviceId, PiPipeconfId) - Method in interface org.onosproject.net.pi.service.PiPipeconfMappingStore
-
Stores or updates a binding between a device and the pipeconf deployed on it.
- createOrUpdateDevice(ProviderId, DeviceId, DeviceDescription) - Method in interface org.onosproject.net.device.DeviceStore
-
Creates a new infrastructure device, or updates an existing one using the supplied device description.
- createOrUpdateDeviceKey(DeviceKey) - Method in interface org.onosproject.net.key.DeviceKeyStore
-
Creates or updates a device key.
- createOrUpdateHost(ProviderId, HostId, HostDescription, boolean) - Method in interface org.onosproject.net.host.HostStore
-
Creates a new host or updates the existing one based on the specified description.
- createOrUpdateLink(ProviderId, LinkDescription) - Method in interface org.onosproject.net.link.LinkStore
-
Creates a new link, or updates an existing one, based on the given information.
- createOutput(PortNumber) - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates an output instruction using the specified port number.
- createPriority(int) - Static method in class org.onlab.packet.pim.PIMHelloOption
-
Creates a new priority option.
- createProtectionEndpoint(ProtectedTransportEndpointDescription) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
-
Creates protected path endpoint.
- createProviderService(P) - Method in class org.onosproject.net.provider.AbstractProviderRegistry
-
Creates a new provider service bound to the specified provider.
- createPruneDelay(short, short) - Static method in class org.onlab.packet.pim.PIMHelloOption
-
Creates a new LAN Prune Delay option.
- createRecursive(DocumentPath, V) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
- createRecursive(DocumentPath, V) - Method in interface org.onosproject.store.service.AsyncDocumentTree
-
Creates a document tree node recursively by creating all missing intermediate nodes in the path.
- createRecursive(DocumentPath, V) - Method in interface org.onosproject.store.service.DocumentTree
-
Creates a document tree node by first creating any missing intermediate nodes in the path.
- createRegion(RegionId, String, Region.Type, List<Set<NodeId>>) - Method in interface org.onosproject.net.region.RegionAdminService
-
Creates a new region using the supplied data.
- createRegion(RegionId, String, Region.Type, Annotations, List<Set<NodeId>>) - Method in interface org.onosproject.net.region.RegionStore
-
Creates a new region using the supplied data.
- createRequestHandlers() - Method in class org.onosproject.ui.UiMessageHandler
-
Subclasses must create and return the collection of request handlers for the message types they handle.
- createSelectGroupBucket(TrafficTreatment) - Static method in class org.onosproject.net.group.DefaultGroupBucket
-
Creates select group bucket with weight as 1.
- createSelectGroupBucket(TrafficTreatment, short) - Static method in class org.onosproject.net.group.DefaultGroupBucket
-
Creates select group bucket with specified weight.
- createSubject(String) - Method in class org.onosproject.net.config.SubjectFactory
-
Creates a configuration subject from its key image.
- createTableModel() - Method in class org.onosproject.ui.table.TableRequestHandler
-
Creates the table model (devoid of data) using
TableRequestHandler.getColumnIds()
to initialize it, ready to be populated. - createTestFiles(List<String>) - Static method in class org.onlab.junit.TestTools
-
Creates a directory tree of test files.
- createTestFiles(List<String>, int, int) - Static method in class org.onlab.junit.TestTools
-
Creates a directory tree of test files.
- createTimer(String, String, String) - Method in interface org.onosproject.core.MetricsHelper
-
Creates a Timer instance with given name.
- createTimer(MetricsComponent, MetricsFeature, String) - Method in class org.onlab.metrics.MetricsManager
-
Creates a Timer metric.
- createTimer(MetricsComponent, MetricsFeature, String) - Method in interface org.onlab.metrics.MetricsService
-
Creates a Timer metric.
- createURLStreamHandler(String) - Method in class org.onlab.junit.HttpResourceUrlInterceptor.HttpResourceUrlInterceptorFactory
- creationTime() - Method in class org.onosproject.common.DefaultTopology
- creationTime() - Method in class org.onosproject.net.topology.DefaultGraphDescription
- creationTime() - Method in interface org.onosproject.net.topology.GraphDescription
-
Returns the creation timestamp of the graph description.
- creationTime() - Method in interface org.onosproject.net.topology.Topology
-
Returns the time, specified in system millis of when the topology became available.
- creationTime() - Method in class org.onosproject.store.service.Versioned
-
Returns the system time when this version was created.
- criteria() - Method in class org.onosproject.net.flow.DefaultTrafficSelector
- criteria() - Method in interface org.onosproject.net.flow.TrafficSelector
-
Returns selection criteria as an ordered list.
- Criteria - Class in org.onosproject.net.flow.criteria
-
Factory class to create various traffic selection criteria.
- Criterion - Interface in org.onosproject.net.flow.criteria
-
Representation of a single header field selection.
- Criterion.IPv6ExthdrFlags - Enum in org.onosproject.net.flow.criteria
-
Bit definitions for IPv6 Extension Header pseudo-field.
- Criterion.TcpFlags - Enum in org.onosproject.net.flow.criteria
- Criterion.Type - Enum in org.onosproject.net.flow.criteria
-
Types of fields to which the selection criterion may apply.
- CRITICAL - org.onlab.packet.IPPrecedence
- CRITICAL - org.onosproject.alarm.Alarm.SeverityLevel
-
From X.733: This indicates that a service affecting condition has occurred and an immediate corrective action is required.
- CROSS_EDGE - org.onlab.graph.DepthFirstSearch.EdgeType
- CROWN - Static variable in class org.onosproject.ui.GlyphConstants
- CS1 - org.onlab.packet.DscpClass
- CS2 - org.onlab.packet.DscpClass
- CS3 - org.onlab.packet.DscpClass
- CS4 - org.onlab.packet.DscpClass
- CS5 - org.onlab.packet.DscpClass
- CS6 - org.onlab.packet.DscpClass
- CS7 - org.onlab.packet.DscpClass
- css() - Method in class org.onosproject.ui.UiExtension
-
Returns input stream containing CSS inclusion statements.
- cssClasses() - Method in class org.onosproject.ui.topo.LinkHighlight
-
Generates the CSS classes string from the
LinkHighlight.flavor
and any optionalLinkHighlight.mods
. - cTag() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
-
Returns the VLAN C-tag of the attachment.
- currentHopLimit - Variable in class org.onlab.packet.ndp.RouterAdvertisement
- currentInputPower(PortNumber, T) - Method in interface org.onosproject.net.behaviour.PowerConfig
-
Get the current input power on the component.
- currentLayout() - Method in interface org.onosproject.ui.UiConnection
-
Returns the current layout context.
- currentPower(PortNumber, T) - Method in interface org.onosproject.net.behaviour.PowerConfig
-
Get the current output power on the component.
- currentTopology() - Method in interface org.onosproject.net.topology.TopologyService
-
Returns the current topology descriptor.
- currentTopology() - Method in interface org.onosproject.net.topology.TopologyStore
-
Returns the current topology snapshot.
- currentView() - Method in interface org.onosproject.ui.UiConnection
-
Returns the current view identifier.
- CWDM - org.onosproject.net.GridType
- CWR - org.onosproject.net.flow.criteria.Criterion.TcpFlags
-
Congestion Window Reduced.
- CYCLE_LABELS - Static variable in class org.onosproject.ui.GlyphConstants
D
- data - Variable in class org.onlab.packet.Data
- data - Variable in class org.onlab.packet.dhcp.DhcpOption
- data - Variable in class org.onlab.packet.EAP
- data() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions.Option
-
Gets the option data.
- data() - Method in class org.onosproject.net.behaviour.DefaultNextGroup
- data() - Method in interface org.onosproject.net.behaviour.NextGroup
-
Serialized form of the next group.
- data() - Method in class org.onosproject.net.driver.AbstractBehaviour
- data() - Method in interface org.onosproject.net.driver.Behaviour
-
Returns the driver data context.
- data() - Method in class org.onosproject.net.driver.DefaultDriverHandler
- data() - Method in interface org.onosproject.net.driver.DriverHandler
-
Returns the device driver data.
- data() - Method in class org.onosproject.net.packet.DefaultOutboundPacket
- data() - Method in interface org.onosproject.net.packet.OutboundPacket
-
Returns immutable view of the raw data to be sent.
- data() - Method in class org.onosproject.net.pi.runtime.PiCounterCell
-
Returns the data contained by this cell.
- data() - Method in class org.onosproject.net.pi.runtime.PiPacketOperation
-
Returns the data of this packet.
- data() - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
-
Returns the data contained by this cell ID.
- data() - Method in class org.onosproject.ui.model.topo.UiModelEvent
-
Returns the data of the subject.
- data(String, Object) - Method in class org.onosproject.ui.chart.ChartModel.DataPoint
-
Sets the data value for the given series of this data point.
- Data - Class in org.onlab.packet
- Data() - Constructor for class org.onlab.packet.Data
- Data(byte[]) - Constructor for class org.onlab.packet.Data
- DATA_CENTER - org.onosproject.net.region.Region.Type
-
Region represents a data center.
- DATALAYER_ADDRESS_LENGTH - Static variable in class org.onlab.packet.Ethernet
- dataLength() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions.Option
-
Gets the option data length (in number of octets).
- dataOffset - Variable in class org.onlab.packet.TCP
- datapathId() - Method in interface org.onosproject.net.behaviour.BridgeDescription
-
Returns OpenFlow datapath ID of the bridge.
- datapathId() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
- datapathId(String) - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
-
Returns bridge description builder with a given datapath ID.
- datapathId(String) - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
- datapathType() - Method in interface org.onosproject.net.behaviour.BridgeDescription
-
Returns OVSDB datapath Type of the bridge.
- datapathType() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
- datapathType(String) - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
-
Returns bridge description builder with a given datapath type.
- datapathType(String) - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
- DataPlaneEntity - Class in org.onosproject.net
-
Generic abstraction to hold dataplane entities.
- DataPlaneEntity(FlowEntry) - Constructor for class org.onosproject.net.DataPlaneEntity
-
Creates a dataplane entity from a flow entry.
- DataPlaneEntity(Group) - Constructor for class org.onosproject.net.DataPlaneEntity
-
Creates a dataplane entity from a group entry.
- DataPlaneEntity.Type - Enum in org.onosproject.net
-
Types of entity.
- DataPoint() - Constructor for class org.onosproject.ui.chart.ChartModel.DataPoint
- dataPointCount() - Method in class org.onosproject.ui.chart.ChartModel
-
Returns the number of data points in this chart model.
- DataRateUnit - Enum in org.onlab.util
-
Data rate unit.
- deactivate() - Method in class org.onosproject.common.net.AbstractDeviceProvider
- deactivate() - Method in class org.onosproject.net.driver.AbstractIndependentDriverLoader
- deactivate() - Method in class org.onosproject.rest.AbstractApiDocRegistrator
- deactivate() - Method in class org.onosproject.store.app.DistributedApplicationStore
- deactivate() - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
- deactivate() - Method in class org.onosproject.ui.UiTopo2Overlay
-
Callback invoked when this overlay is deactivated.
- deactivate() - Method in class org.onosproject.ui.UiTopoOverlay
-
Callback invoked when this overlay is deactivated.
- deactivate(ApplicationId) - Method in interface org.onosproject.app.ApplicationAdminService
-
Deactivates the specified application.
- deactivate(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
-
Mark the application as deactivated.
- deactivate(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
- deactivate(ApplicationId, String) - Method in interface org.onosproject.component.ComponentService
-
Deactivates the component identified by the given name.
- DEACTIVATED - org.onosproject.store.app.DistributedApplicationStore.InternalState
- debug(String) - Method in class org.onlab.junit.LoggerAdapter
- debug(String, Object) - Method in class org.onlab.junit.LoggerAdapter
- debug(String, Object...) - Method in class org.onlab.junit.LoggerAdapter
- debug(String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
- debug(String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
- debug(Marker, String) - Method in class org.onlab.junit.LoggerAdapter
- debug(Marker, String, Object) - Method in class org.onlab.junit.LoggerAdapter
- debug(Marker, String, Object...) - Method in class org.onlab.junit.LoggerAdapter
- debug(Marker, String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
- debug(Marker, String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
- DEBUG - org.onlab.util.Tools.LogLevel
- DEC_MPLS_TTL - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
-
MPLS TTL modification.
- DEC_TTL - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
-
Decrement TTL.
- decapsulateMessage() - Method in class org.onlab.packet.RADIUS
-
Decapsulates an EAP packet from the RADIUS packet.
- DECLINE - org.onlab.packet.DHCP6.MsgType
- decMplsTtl() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- decMplsTtl() - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates a MPLS decrement TTL modification.
- decMplsTtl() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Decrement MPLS TTL.
- decNwTtl() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
- decNwTtl() - Static method in class org.onosproject.net.flow.instructions.Instructions
-
Creates a L3 decrement TTL modification.
- decNwTtl() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
-
Decrement the TTL in IP header by one.
- decode(byte[]) - Method in interface org.onosproject.store.serializers.StoreSerializer
-
Deprecated.Deserializes the specified bytes into an object.
- decode(byte[]) - Method in interface org.onosproject.store.service.Serializer
-
Deserialize the specified bytes.
- decode(int) - Method in interface org.onosproject.net.resource.DiscreteResourceCodec
-
Decodes the specified integer to an object.
- decode(JsonNode, Class<T>) - Method in interface org.onosproject.codec.CodecContext
-
Decodes the specified entity from JSON using codec registered to this context.
- decode(ArrayNode, CodecContext) - Method in class org.onosproject.codec.JsonCodec
-
Decodes the specified JSON array into a collection of entities.
- decode(ObjectNode, CodecContext) - Method in class org.onosproject.codec.JsonCodec
-
Decodes the specified entity from JSON.
- decode(ObjectNode, CodecContext) - Method in interface org.onosproject.net.flow.ExtensionSelectorCodec
-
Decodes an JSON object to an extension selector.
- decode(ObjectNode, CodecContext) - Method in interface org.onosproject.net.flow.ExtensionTreatmentCodec
-
Decodes an JSON object to an extension treatment.
- decode(InputStream) - Method in interface org.onosproject.store.serializers.StoreSerializer
-
Deprecated.Deserializes the specified bytes into an object.
- decode(String, Class<T>) - Method in class org.onosproject.net.config.BaseConfig
-
Decodes the specified entity from JSON using codec registered to this context.
- decode(ByteBuffer) - Method in interface org.onosproject.store.serializers.StoreSerializer
-
Deprecated.Deserializes the specified bytes into an object.
- decreaseRetry() - Method in interface org.onosproject.net.host.HostProbe
-
Decrease retry counter of this entry by one.
- decrementAndGet(K) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
- decrementAndGet(K) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
-
Decrements by one the value currently associated with key, and returns the new value.
- decrementAndGet(K) - Method in interface org.onosproject.store.service.AtomicCounterMap
-
Decrements by one the value currently associated with key, and returns the new value.
- DEFAULT_BUFFER_SIZE - Static variable in class org.onlab.util.KryoNamespace
-
Default buffer size used for serialization.
- DEFAULT_CLASS_OF_SERVICE - Static variable in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
- DEFAULT_DEVICE - Static variable in class org.onlab.packet.ONOSLLDP
- DEFAULT_GENID - Static variable in class org.onlab.packet.pim.PIMHelloOption
- DEFAULT_HOLDTIME - Static variable in class org.onlab.packet.pim.PIMHelloOption
- DEFAULT_HOP_COUNT_WEIGHER - Static variable in class org.onosproject.net.topology.HopCountLinkWeigher
- DEFAULT_HOP_WEIGHT - Static variable in class org.onlab.graph.DefaultEdgeWeigher
-
Default weight based on hop count.
- DEFAULT_ID - Static variable in class org.onosproject.ui.model.topo.UiTopoLayoutId
-
Default topology layout identifier.
- DEFAULT_INITIAL_WEIGHT - Static variable in class org.onlab.graph.DefaultEdgeWeigher
-
Default initial weight.
- DEFAULT_INTENT_PRIORITY - Static variable in class org.onosproject.net.intent.Intent
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6CLTOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6IaNaOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6IaPdOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6IaTaOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.Dhcp6Option
- DEFAULT_LEN - Static variable in class org.onlab.packet.dhcp.DhcpOption
- DEFAULT_MAC - Static variable in interface org.onosproject.net.link.ProbedLinkProvider
- DEFAULT_NAME - Static variable in class org.onlab.packet.ONOSLLDP
- DEFAULT_OPERATION_TIMEOUT_MILLIS - Static variable in interface org.onosproject.store.service.DistributedPrimitive
-
Default timeout for primitive operations.
- DEFAULT_OVERRIDEINTERVAL - Static variable in class org.onlab.packet.pim.PIMHelloOption
- DEFAULT_PERMANENT - Static variable in interface org.onosproject.net.flowobjective.Objective
- DEFAULT_POOL_SIZE - Static variable in class org.onlab.util.SharedExecutors
- DEFAULT_POOL_SIZE - Static variable in class org.onlab.util.SharedScheduledExecutors
- DEFAULT_PORT - Static variable in class org.onosproject.cluster.DefaultControllerNode
- DEFAULT_PRIORITY - Static variable in class org.onlab.packet.pim.PIMHelloOption
- DEFAULT_PRIORITY - Static variable in interface org.onosproject.net.flowobjective.Objective
- DEFAULT_PRUNEDELAY - Static variable in class org.onlab.packet.pim.PIMHelloOption
- DEFAULT_SEPARATOR - Static variable in class org.onosproject.store.service.DocumentPath
-
Default path separator.
- DEFAULT_SEPARATOR_RE - Static variable in class org.onosproject.store.service.DocumentPath
-
Default path separator regex.
- DEFAULT_SPEED - Static variable in class org.onosproject.net.DefaultPort
-
Default port speed in Mbps.
- DEFAULT_TABLE - Static variable in interface org.onosproject.net.flow.FlowRule
- DEFAULT_TIMEOUT - Static variable in interface org.onosproject.net.flowobjective.Objective
- DEFAULT_WEIGHER - Static variable in class org.onosproject.net.topology.AbstractPathService
- DEFAULT_WEIGHT - Static variable in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
- DefaultAlarm - Class in org.onosproject.alarm
-
Default implementation of an alarm.
- DefaultAlarm.Builder - Class in org.onosproject.alarm
-
Builder for the DefaultAlarm object.
- DefaultAnnotations - Class in org.onosproject.net
-
Represents a set of simple annotations that can be used to add arbitrary attributes to various parts of the data model.
- DefaultAnnotations.Builder - Class in org.onosproject.net
-
Facility for gradually building model annotations.
- DefaultApplication - Class in org.onosproject.core
-
Default implementation of network control/management application descriptor.
- DefaultApplication(ApplicationId, Version, String, String, String, String, String, String, byte[], ApplicationRole, Set<Permission>, Optional<URI>, List<String>, List<String>, URL) - Constructor for class org.onosproject.core.DefaultApplication
-
Creates a new application descriptor using the supplied data.
- DefaultApplication.Builder - Class in org.onosproject.core
-
Default application builder.
- DefaultApplicationDescription - Class in org.onosproject.app
-
Default implementation of network control/management application descriptor.
- DefaultApplicationDescription.Builder - Class in org.onosproject.app
-
Default application description builder.
- DefaultApplicationId - Class in org.onosproject.core
-
Application identifier.
- DefaultApplicationId(int, String) - Constructor for class org.onosproject.core.DefaultApplicationId
-
Creates a new application ID.
- DefaultApplicationIdSerializer - Class in org.onosproject.store.serializers
-
Kryo Serializer for
DefaultApplicationId
. - DefaultApplicationIdSerializer() - Constructor for class org.onosproject.store.serializers.DefaultApplicationIdSerializer
-
Creates
DefaultApplicationId
serializer instance. - DefaultAtomicCounter - Class in org.onosproject.store.primitives
-
Default implementation for a
AtomicCounter
backed by aAsyncAtomicCounter
. - DefaultAtomicCounter(AsyncAtomicCounter, long) - Constructor for class org.onosproject.store.primitives.DefaultAtomicCounter
- DefaultAtomicCounterMap<K> - Class in org.onosproject.store.primitives
-
Default implementation of
AtomicCounterMap
. - DefaultAtomicCounterMap(AsyncAtomicCounterMap<K>, long) - Constructor for class org.onosproject.store.primitives.DefaultAtomicCounterMap
- DefaultAtomicIdGenerator - Class in org.onosproject.store.primitives
-
Default implementation for a
AtomicIdGenerator
backed by aAsyncAtomicIdGenerator
. - DefaultAtomicIdGenerator(AsyncAtomicIdGenerator, long) - Constructor for class org.onosproject.store.primitives.DefaultAtomicIdGenerator
- DefaultAtomicValue<V> - Class in org.onosproject.store.primitives
-
Default implementation for a
AtomicValue
backed by aAsyncAtomicValue
. - DefaultAtomicValue(AsyncAtomicValue<V>, long) - Constructor for class org.onosproject.store.primitives.DefaultAtomicValue
- DefaultBand - Class in org.onosproject.net.meter
-
A default implementation for a Band.
- DefaultBand(Band.Type, long, Long, Short) - Constructor for class org.onosproject.net.meter.DefaultBand
- DefaultBand.Builder - Class in org.onosproject.net.meter
- DefaultBridgeDescription - Class in org.onosproject.net.behaviour
-
The default implementation of bridge.
- DefaultBridgeDescription.Builder - Class in org.onosproject.net.behaviour
- DefaultCellComparator - Class in org.onosproject.ui.table.cell
-
A default cell comparator.
- DefaultCellFormatter - Class in org.onosproject.ui.table.cell
-
A default cell formatter.
- defaultColumnId() - Method in class org.onosproject.ui.table.TableRequestHandler
-
Returns the default column ID to be used when one is not supplied in the payload as the column on which to sort.
- DefaultConsistentMap<K,V> - Class in org.onosproject.store.primitives
-
Default implementation of
ConsistentMap
. - DefaultConsistentMap(AsyncConsistentMap<K, V>, long) - Constructor for class org.onosproject.store.primitives.DefaultConsistentMap
- DefaultConsistentMultimap<K,V> - Class in org.onosproject.store.primitives
-
Implementation of
ConsistentMultimap
providing synchronous access toAsyncConsistentMultimap
. - DefaultConsistentMultimap(AsyncConsistentMultimap<K, V>, long) - Constructor for class org.onosproject.store.primitives.DefaultConsistentMultimap
- DefaultConsistentTreeMap<V> - Class in org.onosproject.store.primitives
-
Implementation of the
ConsistentTreeMap
interface. - DefaultConsistentTreeMap(AsyncConsistentTreeMap<V>, long) - Constructor for class org.onosproject.store.primitives.DefaultConsistentTreeMap
- DefaultControllerNode - Class in org.onosproject.cluster
-
Default implementation of a controller instance descriptor.
- DefaultControllerNode(NodeId, String) - Constructor for class org.onosproject.cluster.DefaultControllerNode
-
Creates a new instance with the specified id and IP address.
- DefaultControllerNode(NodeId, String, int) - Constructor for class org.onosproject.cluster.DefaultControllerNode
-
Creates a new instance with the specified id and IP address and TCP port.
- DefaultControllerNode(NodeId, IpAddress) - Constructor for class org.onosproject.cluster.DefaultControllerNode
-
Creates a new instance with the specified id and IP address.
- DefaultControllerNode(NodeId, IpAddress, int) - Constructor for class org.onosproject.cluster.DefaultControllerNode
-
Creates a new instance with the specified id and IP address.
- DefaultControlMessage - Class in org.onosproject.cpman
-
Default control message implementation.
- DefaultControlMessage(ControlMessage.Type, DeviceId, long, long, long, long) - Constructor for class org.onosproject.cpman.DefaultControlMessage
-
Generates a control message instance using given type and statistic information.
- DefaultDevice - Class in org.onosproject.net
-
Default infrastructure device model implementation.
- DefaultDevice(ProviderId, DeviceId, Device.Type, String, String, String, String, ChassisId, Annotations...) - Constructor for class org.onosproject.net.DefaultDevice
-
Creates a network element attributed to the specified provider.
- DefaultDevice.DeviceDriverData - Class in org.onosproject.net
-
Projection of the parent entity as a driver data entity.
- DefaultDeviceDescription - Class in org.onosproject.net.device
-
Default implementation of immutable device description entity.
- DefaultDeviceDescription(URI, Device.Type, String, String, String, String, ChassisId, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.device.DefaultDeviceDescription
-
Creates a device description using the supplied information.
- DefaultDeviceDescription(URI, Device.Type, String, String, String, String, ChassisId, SparseAnnotations...) - Constructor for class org.onosproject.net.device.DefaultDeviceDescription
-
Creates a device description using the supplied information.
- DefaultDeviceDescription(DeviceDescription, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.device.DefaultDeviceDescription
-
Creates a device description using the supplied information.
- DefaultDeviceDescription(DeviceDescription, Device.Type, SparseAnnotations...) - Constructor for class org.onosproject.net.device.DefaultDeviceDescription
-
Creates a device description using the supplied information.
- DefaultDeviceDescription(DeviceDescription, SparseAnnotations...) - Constructor for class org.onosproject.net.device.DefaultDeviceDescription
-
Creates a device description using the supplied information.
- DefaultDeviceInterfaceDescription - Class in org.onosproject.net.device
-
Basic implementation of description of a legacy device interface.
- DefaultDeviceInterfaceDescription(String, DeviceInterfaceDescription.Mode, List<VlanId>, boolean, short) - Constructor for class org.onosproject.net.device.DefaultDeviceInterfaceDescription
-
Device interface description object constructor.
- DefaultDisjointPath - Class in org.onosproject.net
-
Default implementation of a network disjoint path pair.
- DefaultDisjointPath(ProviderId, DefaultPath) - Constructor for class org.onosproject.net.DefaultDisjointPath
-
Creates a disjoint path pair from single default paths.
- DefaultDisjointPath(ProviderId, DefaultPath, DefaultPath) - Constructor for class org.onosproject.net.DefaultDisjointPath
-
Creates a disjoint path pair from two default paths.
- DefaultDistributedLock - Class in org.onosproject.store.primitives
-
Default implementation for a
DistributedLock
backed by aAsyncDistributedLock
. - DefaultDistributedLock(AsyncDistributedLock, long) - Constructor for class org.onosproject.store.primitives.DefaultDistributedLock
- DefaultDistributedSet<E> - Class in org.onosproject.store.primitives
-
Implementation of
DistributedSet
that merely delegates to aAsyncDistributedSet
and waits for the operation to complete. - DefaultDistributedSet(AsyncDistributedSet<E>, long) - Constructor for class org.onosproject.store.primitives.DefaultDistributedSet
- DefaultDocumentTree<V> - Class in org.onosproject.store.primitives
-
Synchronous wrapper for a
AsyncDocumentTree
. - DefaultDocumentTree(AsyncDocumentTree<V>, long) - Constructor for class org.onosproject.store.primitives.DefaultDocumentTree
- DefaultDriver - Class in org.onosproject.net.driver
-
Default implementation of extensible driver.
- DefaultDriver(String, List<Driver>, String, String, String, Map<Class<? extends Behaviour>, Class<? extends Behaviour>>, Map<String, String>) - Constructor for class org.onosproject.net.driver.DefaultDriver
-
Creates a driver with the specified name.
- DefaultDriverData - Class in org.onosproject.net.driver
-
Default implementation of driver data descriptor.
- DefaultDriverData(Driver, DeviceId) - Constructor for class org.onosproject.net.driver.DefaultDriverData
-
Creates new driver data.
- DefaultDriverHandler - Class in org.onosproject.net.driver
-
Default implementation of driver handler.
- DefaultDriverHandler(DriverData) - Constructor for class org.onosproject.net.driver.DefaultDriverHandler
-
Creates new driver handler with the attached driver data.
- DefaultDriverProvider - Class in org.onosproject.net.driver
-
Default driver provider implementation.
- DefaultDriverProvider() - Constructor for class org.onosproject.net.driver.DefaultDriverProvider
- defaultDriverProviderService - Variable in class org.onosproject.net.driver.AbstractDriverLoader
- DefaultDriverProviderService - Interface in org.onosproject.net.driver
-
Deprecated.in Kingfisher release (1.10)
- DefaultEdgeLink - Class in org.onosproject.net
-
Default edge link model implementation.
- DefaultEdgeLink(ProviderId, ConnectPoint, HostLocation, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultEdgeLink
-
Creates an edge link using the supplied information.
- DefaultEdgeWeigher<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Default weigher returns identical weight for every graph edge.
- DefaultEdgeWeigher() - Constructor for class org.onlab.graph.DefaultEdgeWeigher
- DefaultEventSinkRegistry - Class in org.onosproject.event
-
Base implementation of event sink registry.
- DefaultEventSinkRegistry() - Constructor for class org.onosproject.event.DefaultEventSinkRegistry
- DefaultFilteringObjective - Class in org.onosproject.net.flowobjective
-
Default implementation of a filtering objective.
- DefaultFilteringObjective.Builder - Class in org.onosproject.net.flowobjective
- DefaultFlowEntry - Class in org.onosproject.net.flow
- DefaultFlowEntry(FlowRule) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
- DefaultFlowEntry(FlowRule, int, int) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
-
Creates a flow entry of flow table specified with the flow rule, state, live type and statistic information.
- DefaultFlowEntry(FlowRule, FlowEntry.FlowEntryState) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
-
Creates a flow entry based on specified flow rule and state.
- DefaultFlowEntry(FlowRule, FlowEntry.FlowEntryState, long, long, long) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
- DefaultFlowEntry(FlowRule, FlowEntry.FlowEntryState, long, TimeUnit, long, long) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
-
Creates a flow entry of flow table specified with the flow rule, state and statistic information.
- DefaultFlowEntry(FlowRule, FlowEntry.FlowEntryState, long, TimeUnit, FlowEntry.FlowLiveType, long, long) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
-
Creates a flow entry of flow table specified with the flow rule, state and statistic information.
- DefaultFlowEntry(FlowRule, FlowEntry.FlowEntryState, long, FlowEntry.FlowLiveType, long, long) - Constructor for class org.onosproject.net.flow.DefaultFlowEntry
-
Creates a flow entry of flow table specified with the flow rule, state, live type and statistic information.
- DefaultFlowRule - Class in org.onosproject.net.flow
-
Default flow rule.
- DefaultFlowRule(FlowRule) - Constructor for class org.onosproject.net.flow.DefaultFlowRule
-
Creates a new flow rule from an existing rule.
- DefaultFlowRule.Builder - Class in org.onosproject.net.flow
-
Default flow rule builder.
- DefaultForwardingObjective - Class in org.onosproject.net.flowobjective
-
Default implementation of a forwarding objective.
- DefaultForwardingObjective.Builder - Class in org.onosproject.net.flowobjective
- DefaultGraphDescription - Class in org.onosproject.net.topology
-
Default implementation of an immutable topology graph data carrier.
- DefaultGraphDescription(long, long, Iterable<Device>, Iterable<Link>, SparseAnnotations...) - Constructor for class org.onosproject.net.topology.DefaultGraphDescription
-
Creates a minimal topology graph description to allow core to construct and process the topology graph.
- DefaultGroup - Class in org.onosproject.net.group
-
ONOS implementation of default group that is stored in the system.
- DefaultGroup(GroupId, DeviceId, GroupDescription.Type, GroupBuckets) - Constructor for class org.onosproject.net.group.DefaultGroup
-
Default group object constructor with the available information from data plane.
- DefaultGroup(GroupId, GroupDescription) - Constructor for class org.onosproject.net.group.DefaultGroup
-
Default group object constructor with the parameters.
- DefaultGroupBucket - Class in org.onosproject.net.group
-
Group bucket implementation.
- DefaultGroupDescription - Class in org.onosproject.net.group
-
Default implementation of group description interface.
- DefaultGroupDescription(DeviceId, GroupDescription.Type, GroupBuckets) - Constructor for class org.onosproject.net.group.DefaultGroupDescription
-
Constructor to be used by group subsystem internal components.
- DefaultGroupDescription(DeviceId, GroupDescription.Type, GroupBuckets, GroupKey, Integer, ApplicationId) - Constructor for class org.onosproject.net.group.DefaultGroupDescription
-
Constructor to be used by north bound applications.
- DefaultGroupDescription(GroupDescription) - Constructor for class org.onosproject.net.group.DefaultGroupDescription
-
Constructor to be used by group subsystem internal components.
- DefaultGroupKey - Class in org.onosproject.net.group
-
Default implementation of group key interface.
- DefaultGroupKey(byte[]) - Constructor for class org.onosproject.net.group.DefaultGroupKey
- DefaultHashMap<K,V> - Class in org.onlab.util
-
HashMap that returns a default value for unmapped keys.
- DefaultHashMap(V) - Constructor for class org.onlab.util.DefaultHashMap
-
Constructs an empty map with the given default value.
- DefaultHost - Class in org.onosproject.net
-
A basic implementation of a Host.
- DefaultHost(ProviderId, HostId, MacAddress, VlanId, Set<HostLocation>, Set<IpAddress>, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultHost
-
Creates an end-station host using the supplied information.
- DefaultHost(ProviderId, HostId, MacAddress, VlanId, Set<HostLocation>, Set<IpAddress>, VlanId, EthType, boolean, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultHost
-
Creates an end-station host using the supplied information.
- DefaultHost(ProviderId, HostId, MacAddress, VlanId, Set<HostLocation>, Set<IpAddress>, VlanId, EthType, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultHost
-
Creates an end-station host using the supplied information.
- DefaultHost(ProviderId, HostId, MacAddress, VlanId, Set<HostLocation>, Set<HostLocation>, Set<IpAddress>, VlanId, EthType, boolean, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultHost
-
Creates an end-station host using the supplied information.
- DefaultHost(ProviderId, HostId, MacAddress, VlanId, HostLocation, Set<IpAddress>, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultHost
-
Creates an end-station host using the supplied information.
- DefaultHost(ProviderId, HostId, MacAddress, VlanId, HostLocation, Set<IpAddress>, Annotations...) - Constructor for class org.onosproject.net.DefaultHost
-
Creates an end-station host using the supplied information.
- DefaultHostDescription - Class in org.onosproject.net.host
-
Default implementation of an immutable host description.
- DefaultHostDescription(MacAddress, VlanId, Set<HostLocation>, Set<IpAddress>, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, Set<HostLocation>, Set<IpAddress>, VlanId, EthType, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, Set<HostLocation>, Set<HostLocation>, Set<IpAddress>, VlanId, EthType, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, HostLocation, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, HostLocation, Set<IpAddress>, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, HostLocation, Set<IpAddress>, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, HostLocation, IpAddress, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(MacAddress, VlanId, HostLocation, SparseAnnotations...) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultHostDescription(HostDescription, SparseAnnotations) - Constructor for class org.onosproject.net.host.DefaultHostDescription
-
Creates a host description using the supplied information.
- DefaultInboundPacket - Class in org.onosproject.net.packet
-
Default implementation of an immutable inbound packet.
- DefaultInboundPacket(ConnectPoint, Ethernet, ByteBuffer) - Constructor for class org.onosproject.net.packet.DefaultInboundPacket
-
Creates an immutable inbound packet.
- DefaultInboundPacket(ConnectPoint, Ethernet, ByteBuffer, Optional<Long>) - Constructor for class org.onosproject.net.packet.DefaultInboundPacket
-
Creates an immutable inbound packet with cookie.
- DefaultLeaderElector - Class in org.onosproject.store.primitives
-
Default implementation for a
LeaderElector
backed by aAsyncLeaderElector
. - DefaultLeaderElector(AsyncLeaderElector, long) - Constructor for class org.onosproject.store.primitives.DefaultLeaderElector
- DefaultLink - Class in org.onosproject.net
-
Default infrastructure link model implementation.
- DefaultLink(ProviderId, ConnectPoint, ConnectPoint, Link.Type, Link.State, Annotations...) - Constructor for class org.onosproject.net.DefaultLink
-
Creates an infrastructure link using the supplied information.
- DefaultLink.Builder - Class in org.onosproject.net
-
Builder for DefaultLink objects.
- DefaultLinkDescription - Class in org.onosproject.net.link
-
Default implementation of immutable link description entity.
- DefaultLinkDescription(ConnectPoint, ConnectPoint, Link.Type, boolean, SparseAnnotations...) - Constructor for class org.onosproject.net.link.DefaultLinkDescription
-
Creates a link description using the supplied information.
- DefaultLinkDescription(ConnectPoint, ConnectPoint, Link.Type, SparseAnnotations...) - Constructor for class org.onosproject.net.link.DefaultLinkDescription
-
Creates a link description using the supplied information.
- DefaultLinkSerializer - Class in org.onosproject.store.serializers
-
Kryo Serializer for
DefaultLink
. - DefaultLinkSerializer() - Constructor for class org.onosproject.store.serializers.DefaultLinkSerializer
-
Creates
DefaultLink
serializer instance. - DefaultLoad - Class in org.onosproject.net.statistic
-
Implementation of a load.
- DefaultLoad() - Constructor for class org.onosproject.net.statistic.DefaultLoad
-
Creates an invalid load.
- DefaultLoad(long, long) - Constructor for class org.onosproject.net.statistic.DefaultLoad
-
Creates a load value from the parameters.
- DefaultLoad(long, long, long) - Constructor for class org.onosproject.net.statistic.DefaultLoad
-
Creates a load value from the parameters.
- defaultMac() - Static method in interface org.onosproject.net.link.ProbedLinkProvider
- DefaultMeter - Class in org.onosproject.net.meter
-
A default implementation of a meter.
- DefaultMeter.Builder - Class in org.onosproject.net.meter
- DefaultMeterFeatures - Class in org.onosproject.net.meter
-
Default implementation of MeterFeatures.
- DefaultMeterFeatures.Builder - Class in org.onosproject.net.meter
-
A DefaultMeterFeatures builder.
- DefaultMeterRequest - Class in org.onosproject.net.meter
-
A default implementation of a meter.
- DefaultMeterRequest.Builder - Class in org.onosproject.net.meter
- DefaultMirroringDescription - Class in org.onosproject.net.behaviour
-
Default implementation of mirroring description entity.
- DefaultMirroringDescription(MirroringName, List<String>, List<String>, List<VlanId>, Optional<String>, Optional<VlanId>, SparseAnnotations...) - Constructor for class org.onosproject.net.behaviour.DefaultMirroringDescription
-
Creates a mirroring description using the supplied information.
- DefaultMutablePath<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Simple concrete implementation of a directed graph path.
- DefaultMutablePath() - Constructor for class org.onlab.graph.DefaultMutablePath
-
Creates a new empty path.
- DefaultMutablePath(Path<V, E>) - Constructor for class org.onlab.graph.DefaultMutablePath
-
Creates a new path as a copy of another path.
- DefaultNeighbourMessageHandler - Class in org.onosproject.net.neighbour
-
Default neighbour message handler which implements basic proxying on an L2 network (i.e.
- DefaultNeighbourMessageHandler() - Constructor for class org.onosproject.net.neighbour.DefaultNeighbourMessageHandler
- DefaultNextGroup - Class in org.onosproject.net.behaviour
-
Default implementation of a next group.
- DefaultNextGroup(byte[]) - Constructor for class org.onosproject.net.behaviour.DefaultNextGroup
- DefaultNextObjective - Class in org.onosproject.net.flowobjective
-
Default implementation of a next objective.
- DefaultNextObjective.Builder - Class in org.onosproject.net.flowobjective
- DefaultNextTreatment - Class in org.onosproject.net.flowobjective
-
Represents a next action specified by traffic treatment.
- DefaultObjectiveContext - Class in org.onosproject.net.flowobjective
-
Implementation of objective context that delegates calls to provided consumers.
- DefaultObjectiveContext(BiConsumer<Objective, ObjectiveError>) - Constructor for class org.onosproject.net.flowobjective.DefaultObjectiveContext
-
Creates a new objective context using the given error consumer.
- DefaultObjectiveContext(Consumer<Objective>) - Constructor for class org.onosproject.net.flowobjective.DefaultObjectiveContext
-
Creates a new objective context using the given success consumer.
- DefaultObjectiveContext(Consumer<Objective>, BiConsumer<Objective, ObjectiveError>) - Constructor for class org.onosproject.net.flowobjective.DefaultObjectiveContext
-
Creates a new objective context using the given success and error consumers.
- DefaultOchSignalComparator - Class in org.onosproject.net
-
Comparator implementation for OchSignal.
- DefaultOchSignalComparator() - Constructor for class org.onosproject.net.DefaultOchSignalComparator
- defaultOffsetDataTime(long) - Static method in class org.onlab.util.Tools
-
Creates OffsetDateTime instance from epoch milliseconds, using system default time zone.
- DefaultOutboundPacket - Class in org.onosproject.net.packet
-
Default implementation of an immutable outbound packet.
- DefaultOutboundPacket(DeviceId, TrafficTreatment, ByteBuffer) - Constructor for class org.onosproject.net.packet.DefaultOutboundPacket
-
Creates an immutable outbound packet.
- DefaultOutboundPacket(DeviceId, TrafficTreatment, ByteBuffer, PortNumber) - Constructor for class org.onosproject.net.packet.DefaultOutboundPacket
-
Creates an immutable outbound packet.
- DefaultOutboundPacketSerializer - Class in org.onosproject.store.serializers
-
Serializer for a default outbound packet.
- DefaultOutboundPacketSerializer() - Constructor for class org.onosproject.store.serializers.DefaultOutboundPacketSerializer
-
Creates
DefaultOutboundPacket
serializer instance. - DefaultPacketContext - Class in org.onosproject.net.packet
-
Default implementation of a packet context.
- DefaultPacketContext(long, InboundPacket, OutboundPacket, boolean) - Constructor for class org.onosproject.net.packet.DefaultPacketContext
-
Creates a new packet context.
- DefaultPacketInFilter - Class in org.onosproject.net.packet.packetfilter
-
Default implementation of a packet-in filter.
- DefaultPacketInFilter(int, int, int, int, String, PacketInClassifier) - Constructor for class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
-
Only one filter object per packet type to be associated.
- DefaultPacketRequest - Class in org.onosproject.net.packet
-
Default implementation of a packet request.
- DefaultPacketRequest(TrafficSelector, PacketPriority, ApplicationId, NodeId, Optional<DeviceId>) - Constructor for class org.onosproject.net.packet.DefaultPacketRequest
-
Creates a new packet request.
- DefaultPartition - Class in org.onosproject.cluster
-
Default
Partition
implementation. - DefaultPartition() - Constructor for class org.onosproject.cluster.DefaultPartition
-
Constructs an empty partition for the serializer.
- DefaultPartition(Partition) - Constructor for class org.onosproject.cluster.DefaultPartition
-
Constructs a partition that is a copy of another.
- DefaultPartition(PartitionId, Collection<NodeId>) - Constructor for class org.onosproject.cluster.DefaultPartition
-
Constructs a partition.
- DefaultPatchDescription - Class in org.onosproject.net.behaviour
-
Default implementation of immutable patch interface description entity.
- DefaultPatchDescription.Builder - Class in org.onosproject.net.behaviour
- DefaultPath<V extends Vertex,E extends Edge<V>> - Class in org.onlab.graph
-
Simple concrete implementation of a directed graph path.
- DefaultPath - Class in org.onosproject.net
-
Default implementation of a network path.
- DefaultPath(List<E>, Weight) - Constructor for class org.onlab.graph.DefaultPath
-
Creates a new path from the specified list of edges and cost.
- DefaultPath(ProviderId, List<Link>, Weight, Annotations...) - Constructor for class org.onosproject.net.DefaultPath
-
Creates a path from the specified source and destination using the supplied list of links.