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

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 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 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
Creates a new topo monitor base.
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.behaviour.upf.UpfInterface.Type
Interface that receives GTP encapsulated packets.
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.PiActionSet.WeightedAction
 
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.
ACTION_SET - org.onosproject.net.pi.runtime.PiTableAction.Type
Executes the given 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.
actions() - Method in class org.onosproject.net.pi.runtime.PiActionSet
Returns the set of actions.
actionString() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Return a string representing the dataplane action applied by this FAR.
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.
addFar(ForwardingActionRule) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Add a Forwarding Action Rule (FAR) to the given device.
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(UpfInterface) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Install a new interface on the UPF device's interface lookup tables.
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
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 specified ListenerService.
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.
addOrUpdateMeter(Meter) - Method in interface org.onosproject.net.meter.MeterStore
Adds a meter to the store or updates a meter in the store.
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.
addPdr(PacketDetectionRule) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Add a Packet Detection Rule (PDR) to the given device.
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.
addPorts(BridgeName, List<String>) - Method in interface org.onosproject.net.behaviour.BridgeConfig
Adds ports 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.
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.
addWeightedAction(PiAction, int) - Method in class org.onosproject.net.pi.runtime.PiActionSet.Builder
Adds a weighted action to this action set.
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
Deprecated.
in onos-2.5
allocateMeterId(DeviceId, MeterScope) - 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
 
architecture() - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns the data plane target architecture supported by this pipeline model.
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_THA - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
ARP Ether dst modification.
ARP_TPA - org.onosproject.net.flow.criteria.Criterion.Type
ARP target IPv4 address.
ARP_TPA - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
ARP IP dst modification.
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.
availability() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link availability in terms of percentage.
availability(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link availability.
AVAILABILITY - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for availability.
AVAILABILITY - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
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 to CodecService.
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 BaseLinks.
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 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 of DriverHandler).
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
 
BitErrorCommand - Class in org.onosproject.cli.net
Get the bit-error-rate for specific optical-channel.
BitErrorCommand() - Constructor for class org.onosproject.cli.net.BitErrorCommand
 
BitErrorRateState - Interface in org.onosproject.net.behaviour
 
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 a CompletableFuture.get() or CompletableFuture.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.
Bmp - Class in org.onlab.packet.bmp
The following common header appears in all BMP messages.
Bmp() - Constructor for class org.onlab.packet.bmp.Bmp
 
BmpPeer - Class in org.onlab.packet.bmp
The per-peer header follows the common header for most BMP messages.
BmpPeer() - Constructor for class org.onlab.packet.bmp.BmpPeer
 
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.
buffers() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Returns true if this FAR buffers incoming packets, and false otherwise.
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
build() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription.Builder
build() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
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.behaviour.upf.ForwardingActionRule.Builder
 
build() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
 
build() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
 
build() - Method in class org.onosproject.net.behaviour.upf.PdrStats.Builder
 
build() - Method in class org.onosproject.net.behaviour.upf.UpfInterface.Builder
 
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.PiActionSet.Builder
Creates a new action profile action set.
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
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
builder() - Static method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription
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.behaviour.upf.ForwardingActionRule
 
builder() - Static method in class org.onosproject.net.behaviour.upf.GtpTunnel
 
builder() - Static method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
 
builder() - Static method in class org.onosproject.net.behaviour.upf.PdrStats
 
builder() - Static method in class org.onosproject.net.behaviour.upf.UpfInterface
 
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.PiActionSet
Returns a new builder of an action set.
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.behaviour.upf.ForwardingActionRule.Builder
 
Builder() - Constructor for class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
 
Builder() - Constructor for class org.onosproject.net.behaviour.upf.PdrStats.Builder
 
Builder() - Constructor for class org.onosproject.net.behaviour.upf.UpfInterface.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_PER_SEC - org.onosproject.net.meter.Meter.Unit
Bytes per 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() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Remove any state previously created by this API.
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.
clearFlows() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Remove all UE flows (PDRs, FARs) currently installed on the UPF-programmable device.
clearInterfaces() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Remove all interfaces currently installed on the UPF-programmable device.
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(ClusterEvent.Type, ControllerNode, long, ClusterEvent.InstanceType) - Constructor for class org.onosproject.cluster.ClusterEvent
Creates an event of a given type and for the specified device and time.
ClusterEvent(ClusterEvent.Type, ControllerNode, ClusterEvent.InstanceType) - Constructor for class org.onosproject.cluster.ClusterEvent
Creates an event of a given type and for the specified instance and the current time.
ClusterEvent.InstanceType - Enum in org.onosproject.cluster
 
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.net.pi.runtime.PiMeterBandType
Committed band config.
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.
committedBand() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
Returns the committed configuration if present.
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.
CONNECTION_TYPE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for UI connection type (the style for host link rendering).
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 as AsyncConsistentMap 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 a ConsistentMap.
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.
copyAndFit(ByteBuffer, int) - Static method in class org.onlab.util.ImmutableByteSequence
Creates a new immutable byte sequence while trimming or expanding the content of the given byte buffer to fit the given bit-width.
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(String) - Static method in class org.onlab.util.ImmutableByteSequence
Creates a new immutable byte sequence from the given string.
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 - org.onosproject.net.behaviour.upf.UpfInterface.Type
Interface that receives unencapsulated packets from the core of the network.
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
 
cost(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.TierConstraint
 
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.
costType() - Method in class org.onosproject.net.intent.constraint.TierConstraint
Return the cost model used by this constraint.
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 a long 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_INDEX_OUT_OF_RANGE - org.onosproject.net.behaviour.upf.UpfProgrammableException.Type
A provided counter cell index was out of range.
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.behaviour.upf.PacketDetectionRule
Get the dataplane PDR counter cell ID that this PDR is assigned.
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.
createDbufReceiverFrom(Ip4Address) - Static method in class org.onosproject.net.behaviour.upf.UpfInterface
Create a dbuf-receiving UPF interface from the given IP address.
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.
createHighlights() - Method in interface org.onosproject.ui.UiTopoHighlighter
Generate a set of highlights.
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.
createS1uFrom(Ip4Address) - Static method in class org.onosproject.net.behaviour.upf.UpfInterface
Create a core-facing UPF Interface from the given address, which will be treated as a /32 prefix.
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.
createUePoolFrom(Ip4Prefix) - Static method in class org.onosproject.net.behaviour.upf.UpfInterface
Create a core-facing UPF Interface from the given IP prefix.
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 optional LinkHighlight.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
 
DATAPATH_DESCRIPTION - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the datapath description.
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.
DBUF - org.onosproject.net.behaviour.upf.UpfInterface.Type
Interface that receives buffered packets as they are drained from a dbuf device.
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_HEADER_LENGTH - Static variable in class org.onlab.packet.bmp.Bmp
 
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_PACKET_MINIMUM_LENGTH - Static variable in class org.onlab.packet.bmp.Bmp
 
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 interface org.onosproject.net.flowobjective.NextTreatment
 
DEFAULT_WEIGHT - Static variable in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
 
DEFAULT_WEIGHT - Static variable in class org.onosproject.net.pi.runtime.PiActionSet.WeightedAction
 
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 a AsyncAtomicCounter.
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 a AsyncAtomicIdGenerator.
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 a AsyncAtomicValue.
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 to AsyncConsistentMultimap.
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 a AsyncDistributedLock.
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 a AsyncDistributedSet 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 a AsyncLeaderElector.
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 and weight.
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.
DefaultPiPipeconf - Class in org.onosproject.net.pi.model
Default pipeconf implementation.
DefaultPiPipeconf.Builder - Class in org.onosproject.net.pi.model
Builder of pipeconf implementations.
DefaultPolicer - Class in org.onosproject.net.behaviour.trafficcontrol
Default implementation of the policer interface.
DefaultPolicer.Builder - Class in org.onosproject.net.behaviour.trafficcontrol
Implementation of the policer builder interface.
DefaultPort - Class in org.onosproject.net
Default port implementation.
DefaultPort(Element, PortNumber, boolean, Annotations...) - Constructor for class org.onosproject.net.DefaultPort
Creates a network element attributed to the specified provider.
DefaultPort(Element, PortNumber, boolean, Port.Type, long, Annotations...) - Constructor for class org.onosproject.net.DefaultPort
Creates a network element attributed to the specified provider.
DefaultPortDescription - Class in org.onosproject.net.device
Default implementation of immutable port description.
DefaultPortDescription() - Constructor for class org.onosproject.net.device.DefaultPortDescription
 
DefaultPortDescription.Builder - Class in org.onosproject.net.device
 
DefaultPortSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for DefaultPort.
DefaultPortSerializer() - Constructor for class org.onosproject.store.serializers.DefaultPortSerializer
Creates DefaultPort serializer instance.
DefaultPortStatistics - Class in org.onosproject.net.device
Default implementation of immutable port statistics.
DefaultPortStatistics.Builder - Class in org.onosproject.net.device
 
defaultProvider() - Method in class org.onosproject.net.provider.AbstractProviderRegistry
Returns the default fall-back provider.
DefaultQosDescription - Class in org.onosproject.net.behaviour
Default implementation of Qos description entity.
DefaultQosDescription.Builder - Class in org.onosproject.net.behaviour
 
DefaultQueueDescription - Class in org.onosproject.net.behaviour
Default implementation of Queue description entity.
DefaultQueueDescription.Builder - Class in org.onosproject.net.behaviour
 
DefaultRegion - Class in org.onosproject.net.region
Default implementation of a region.
DefaultRegion(RegionId, String, Region.Type, Annotations, List<Set<NodeId>>) - Constructor for class org.onosproject.net.region.DefaultRegion
Creates a region using the supplied information.
DefaultResult(V, V) - Constructor for class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
Creates the result of a single-path search.
DefaultResult(V, V, int) - Constructor for class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
Creates the result of path search.
DefaultServiceDirectory - Class in org.onlab.osgi
Default implementation of the service directory using OSGi framework utilities.
DefaultServiceDirectory() - Constructor for class org.onlab.osgi.DefaultServiceDirectory
 
DefaultTableStatisticsEntry - Class in org.onosproject.net.flow
Default implementation of table statistics entry interface.
DefaultTableStatisticsEntry.Builder - Class in org.onosproject.net.flow
 
DefaultTokenBucket - Class in org.onosproject.net.behaviour.trafficcontrol
Default implementation of the token bucket interface.
DefaultTokenBucket.Builder - Class in org.onosproject.net.behaviour.trafficcontrol
Implementation of the token bucket builder interface.
DefaultTopology - Class in org.onosproject.common
Default implementation of the topology descriptor.
DefaultTopology(ProviderId, GraphDescription) - Constructor for class org.onosproject.common.DefaultTopology
Creates a topology descriptor attributed to the specified provider.
DefaultTopology(ProviderId, GraphDescription, Function<ConnectPoint, Boolean>) - Constructor for class org.onosproject.common.DefaultTopology
Creates a topology descriptor attributed to the specified provider.
DefaultTopologyCluster - Class in org.onosproject.net.topology
Default implementation of a network topology cluster.
DefaultTopologyCluster(ClusterId, int, int, TopologyVertex) - Constructor for class org.onosproject.net.topology.DefaultTopologyCluster
Creates a new topology cluster descriptor with the specified attributes.
DefaultTopologyEdge - Class in org.onosproject.net.topology
Implementation of the topology edge backed by a link.
DefaultTopologyEdge(TopologyVertex, TopologyVertex, Link) - Constructor for class org.onosproject.net.topology.DefaultTopologyEdge
Creates a new topology edge.
DefaultTopologyGraph - Class in org.onosproject.common
Default implementation of an immutable topology graph based on a generic implementation of adjacency lists graph.
DefaultTopologyGraph(Set<TopologyVertex>, Set<TopologyEdge>) - Constructor for class org.onosproject.common.DefaultTopologyGraph
Creates a topology graph comprising of the specified vertexes and edges.
DefaultTopologyVertex - Class in org.onosproject.net.topology
Implementation of the topology vertex backed by a device id.
DefaultTopologyVertex(DeviceId) - Constructor for class org.onosproject.net.topology.DefaultTopologyVertex
Creates a new topology vertex.
DefaultTrafficSelector - Class in org.onosproject.net.flow
Default traffic selector implementation.
DefaultTrafficSelector.Builder - Class in org.onosproject.net.flow
Builder of traffic selector entities.
DefaultTrafficTreatment - Class in org.onosproject.net.flow
Default traffic treatment implementation.
DefaultTrafficTreatment.Builder - Class in org.onosproject.net.flow
Builds a list of treatments following the following order.
DefaultTunnelDescription - Class in org.onosproject.net.behaviour
Default implementation of immutable tunnel interface description entity.
DefaultTunnelDescription.Builder - Class in org.onosproject.net.behaviour
 
DefaultTypedFlowEntry - Class in org.onosproject.net.flow
Default flow entry class with FlowLiveType value, IMMEDIATE_FLOW, SHORT_FLOW, MID_FLOW, LONG_FLOW.
DefaultTypedFlowEntry(FlowEntry) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow entry, with default flow live type(IMMEDIATE_FLOW).
DefaultTypedFlowEntry(FlowEntry, TypedStoredFlowEntry.FlowLiveType) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow entry and flow live type.
DefaultTypedFlowEntry(FlowRule) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow rule, with default flow live type(IMMEDIATE_FLOW).
DefaultTypedFlowEntry(FlowRule, int, int, TypedStoredFlowEntry.FlowLiveType) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow rule, error code and flow live type.
DefaultTypedFlowEntry(FlowRule, FlowEntry.FlowEntryState, long, long, long) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow rule and its statistics, with default flow live type(IMMEDIATE_FLOW).
DefaultTypedFlowEntry(FlowRule, FlowEntry.FlowEntryState, long, TimeUnit, long, long) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow rule and its statistics, with default flow live type(IMMEDIATE_FLOW).
DefaultTypedFlowEntry(FlowRule, TypedStoredFlowEntry.FlowLiveType) - Constructor for class org.onosproject.net.flow.DefaultTypedFlowEntry
Creates a typed flow entry from flow rule and flow live type.
defaultValue() - Method in class org.onosproject.cfg.ConfigProperty
Returns the property default value as a string.
deferred() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
deferred() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
deferred() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Any instructions followed by this method call will be deferred.
deferred() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the list of treatment instructions that will be applied further down the pipeline.
defineProperty(String, ConfigProperty.Type, String, String) - Static method in class org.onosproject.cfg.ConfigProperty
Creates a new configuration property with its default value.
DEFRAG_TIME_EXCEED - org.onosproject.cli.net.Icmp6Code
Fragment reassembly time exceeded.
DEFRAG_TIME_EXCEED - Static variable in class org.onlab.packet.ICMP6
Fragment reassembly time exceeded.
DEI - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Action
Marking sets Drop Elegible Indicator.
delay() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link delay in terms of seconds.
delay(int) - Static method in class org.onlab.junit.TestTools
Suspends the current thread for a specified number of millis.
delay(int) - Static method in class org.onlab.util.Tools
Suspends the current thread for a specified number of millis.
delay(int) - Method in class org.onosproject.ui.topo.Highlights
Sets the number of milliseconds to delay processing of highlights events on the client side.
delay(int, int) - Static method in class org.onlab.util.Tools
Suspends the current thread for a specified number of millis and nanos.
delay(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link delay.
DELAY - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for delay.
DELAY - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
DELAY_PROTECT_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
delayMs() - Method in class org.onosproject.ui.topo.Highlights
Return the delay for the highlight event.
delegate - Variable in class org.onosproject.net.config.Config
 
delegate - Variable in class org.onosproject.store.AbstractStore
 
delegate() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
delegate() - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
DELETE - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
DELETE - org.onosproject.net.group.GroupOperation.Type
Delete a specified group.
DELETE_NODE - org.onosproject.store.primitives.NodeUpdate.Type
Deletes an entry if the current version matches specified version.
deleteBridge(BridgeName) - Method in interface org.onosproject.net.behaviour.BridgeConfig
Remove a bridge.
DELETED - org.onosproject.store.service.DocumentTreeEvent.Type
Signifies an existing node being deleted.
deleteDeviceKey(DeviceKeyId) - Method in interface org.onosproject.net.key.DeviceKeyStore
Deletes a device key by a specific device key identifier.
deleteFlowRule(FlowRule) - Method in interface org.onosproject.net.flow.FlowRuleStore
Marks a flow rule for deletion.
deleteGroupDescription(DeviceId, GroupKey) - Method in interface org.onosproject.net.group.GroupStore
Triggers deleting the existing group entry.
deleteMeter(Meter) - Method in interface org.onosproject.net.meter.MeterStore
Deletes a meter from the store.
deleteMeterFeatures(Collection<MeterFeatures>) - Method in interface org.onosproject.net.meter.MeterStore
Deletes a collection of meter features from the store.
deleteMeterFeatures(DeviceId) - Method in interface org.onosproject.net.meter.MeterProviderService
Delete meter features collected from the device.
deleteMeterFeatures(DeviceId) - Method in interface org.onosproject.net.meter.MeterStore
Deletes the meter features from the store.
deleteMirroring(MirroringName) - Method in interface org.onosproject.net.behaviour.MirroringConfig
Removes a mirroring.
deletePolicer(PolicerId) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerConfigurable
 
deletePort(BridgeName, String) - Method in interface org.onosproject.net.behaviour.BridgeConfig
Removes a port from a given bridge.
deletePort(DeviceId, PortDescription) - Method in interface org.onosproject.net.device.DeviceProviderService
Delete information about a single port of a device.
deletePorts(BridgeName, List<String>) - Method in interface org.onosproject.net.behaviour.BridgeConfig
Deletes ports to a given bridge.
deleteProtectionEndpoint(ConnectPoint) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Deletes protected path endpoint.
deleteQoS(QosId) - Method in interface org.onosproject.net.behaviour.QosConfigBehaviour
Delete a QoS configuration.
deleteQueue(QueueId) - Method in interface org.onosproject.net.behaviour.QueueConfigBehaviour
Delete a queue from a device.
deleteQueues(QosId, List<Long>) - Method in interface org.onosproject.net.behaviour.QosConfigBehaviour
delete queue from qos.
DELIMITER - Static variable in class org.onlab.util.GroupedThreadFactory
 
deny() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
deny() - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Deny this filtering condition set.
DENY - org.onosproject.net.flowobjective.FilteringObjective.Type
Denies packets that make it through the permit filters.
DepthFirstSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
DFS graph search algorithm implemented via iteration rather than recursion.
DepthFirstSearch() - Constructor for class org.onlab.graph.DepthFirstSearch
 
DepthFirstSearch.EdgeType - Enum in org.onlab.graph
Graph edge types as classified by the DFS algorithm.
DepthFirstSearch.SpanningTreeResult - Class in org.onlab.graph
Graph search result which includes edge classification for building a spanning tree.
DESC - org.onosproject.ui.table.TableModel.SortDir
Designates a descending sort.
descendingIterator() - Method in class org.onlab.util.UnmodifiableDeque
 
describeMismatch(Description) - Method in class org.onlab.junit.ImmutableClassChecker
Describe why an error was reported.
describeMismatch(Description) - Method in class org.onlab.junit.UtilityClassChecker
Describe why an error was reported.
describeTo(Description) - Method in class org.onlab.junit.ImmutableClassChecker
Describe the source object that caused an error, using a Hamcrest Matcher style interface.
describeTo(Description) - Method in class org.onlab.junit.UtilityClassChecker
Describe the source object that caused an error, using a Hamcrest Matcher style interface.
description() - Method in interface org.onosproject.alarm.Alarm
Returns a description of alarm.
description() - Method in class org.onosproject.alarm.DefaultAlarm
 
description() - Method in interface org.onosproject.app.ApplicationDescription
Returns description of the application.
description() - Method in class org.onosproject.app.DefaultApplicationDescription
 
description() - Method in class org.onosproject.cfg.ConfigProperty
Returns the property description.
description() - Method in interface org.onosproject.core.Application
Returns description of the application.
description() - Method in class org.onosproject.core.DefaultApplication
 
description() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
Returns the description of this ProtectedPathEndPoint.
description() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState
Returns description associated to this state.
description() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
description() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
Brief description of this policer.
description() - Method in class org.onosproject.net.intent.ProtectionEndpointIntent
Returns the description of this protection endpoint.
description() - Method in class org.onosproject.ui.UiTopoMap
Returns the description for this map.
description(ProtectedTransportEndpointDescription) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
 
Description - Interface in org.onosproject.net
Base abstraction of a piece of information about network elements.
DeserializationException - Exception in org.onlab.packet
Signals that an error occurred during deserialization of a packet.
DeserializationException(String) - Constructor for exception org.onlab.packet.DeserializationException
Creates a new deserialization exception with the given message.
deserialize(byte[]) - Static method in class org.onlab.packet.dhcp.CircuitId
Deserialize circuit id from byte string.
deserialize(byte[]) - Method in class org.onlab.util.KryoNamespace
Deserializes given byte array to Object using Kryo instance in pool.
deserialize(byte[]) - Method in class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
 
deserialize(byte[]) - Method in interface org.onosproject.net.flow.Extension
Deserialize the extension from a byte array.
deserialize(byte[]) - Method in class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
 
deserialize(byte[], int, int) - Method in interface org.onlab.packet.Deserializer
Deserialize a packet object from a byte array.
deserialize(byte[], int, int) - Method in class org.onlab.packet.pim.PIMAddrSource
 
deserialize(byte[], int, int) - Method in class org.onlab.packet.pim.PIMHello
XXX: This is deprecated, DO NOT USE, use the deserializer() function instead.
deserialize(InputStream) - Method in class org.onlab.util.KryoNamespace
Deserializes given InputStream to an Object using Kryo instance in pool.
deserialize(InputStream, int) - Method in class org.onlab.util.KryoNamespace
Deserializes given InputStream to an Object using Kryo instance in pool.
deserialize(ByteBuffer) - Method in class org.onlab.packet.IGMPGroup
Deserialize an IGMPQuery or IGMPMembership message.
deserialize(ByteBuffer) - Method in class org.onlab.packet.IGMPMembership
Deserialize the IGMP Membership report packet.
deserialize(ByteBuffer) - Method in class org.onlab.packet.IGMPQuery
Deserialize the IGMP Query group structure.
deserialize(ByteBuffer) - Method in class org.onlab.packet.LLDPOrganizationalTLV
 
deserialize(ByteBuffer) - Method in class org.onlab.packet.LLDPTLV
 
deserialize(ByteBuffer) - Method in class org.onlab.packet.pim.PIMAddrGroup
Deserialze from a ByteBuffer.
deserialize(ByteBuffer) - Method in class org.onlab.packet.pim.PIMAddrSource
 
deserialize(ByteBuffer) - Method in class org.onlab.packet.pim.PIMAddrUnicast
 
deserialize(ByteBuffer) - Static method in class org.onlab.packet.pim.PIMHelloOption
 
deserialize(ByteBuffer) - Method in class org.onlab.util.KryoNamespace
Deserializes given byte buffer to Object using Kryo instance in pool.
deserializer() - Static method in class org.onlab.packet.ARP
Deserializer function for ARP packets.
deserializer() - Static method in class org.onlab.packet.bmp.Bmp
Deserializer function for Bmp Packets.
deserializer() - Static method in class org.onlab.packet.bmp.BmpPeer
 
deserializer() - Static method in class org.onlab.packet.Data
Deserializer function for generic payload data.
deserializer() - Static method in class org.onlab.packet.DHCP
Deserializer function for DHCP packets.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6CLTOption
Gets deserializer.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6Duid
 
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Gets deserializer.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Gets deserializer.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
Gets deserializer.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Gets deserializer for DHCPv6 relay option.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6Option
Gets deserializer of DHCPv6 option.
deserializer() - Static method in class org.onlab.packet.dhcp.Dhcp6RelayOption
Gets deserializer for DHCPv6 relay option.
deserializer() - Static method in class org.onlab.packet.dhcp.DhcpOption
Deserializer function for DHCP option.
deserializer() - Static method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
Deserializer function for DHCP relay agent option.
deserializer() - Static method in class org.onlab.packet.DHCP6
Returns a deserializer for DHCPv6.
deserializer() - Static method in class org.onlab.packet.EAP
Deserializer for EAP packets.
deserializer() - Static method in class org.onlab.packet.EAPOL
Deserializer for EAPOL packets.
deserializer() - Static method in class org.onlab.packet.EAPOLMkpdu
Static deserializer for EAPOL-MKA packets.
deserializer() - Static method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
Deserializer function for Basic Parameter Set.
deserializer() - Static method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
Deserializer function for Distributed SAK Parameter Set.
deserializer() - Static method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
Deserializer function for ICV Indicator Parameter Set.
deserializer() - Static method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Deserializer function for MACSec SAK Use Parameter Set.
deserializer() - Static method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
Deserializer function for Peer List Parameter Set.
deserializer() - Static method in class org.onlab.packet.Ethernet
Deserializer function for Ethernet packets.
deserializer() - Method in enum org.onlab.packet.EthType.EtherType
 
deserializer() - Static method in class org.onlab.packet.ICMP
Deserializer function for ICMP packets.
deserializer() - Static method in class org.onlab.packet.ICMP6
Deserializer function for ICMPv6 packets.
deserializer() - Static method in class org.onlab.packet.ICMPEcho
Deserializer function for ICMPEcho packets.
deserializer() - Static method in class org.onlab.packet.IGMP
Deserializer function for IPv4 packets.
deserializer() - Static method in class org.onlab.packet.IP
Deserializer function for IP packets.
deserializer() - Static method in class org.onlab.packet.IPv4
Deserializer function for IPv4 packets.
deserializer() - Static method in class org.onlab.packet.ipv6.Authentication
Deserializer function for authentication headers.
deserializer() - Static method in class org.onlab.packet.ipv6.BaseOptions
Deserializer function for IPv6 base options.
deserializer() - Static method in class org.onlab.packet.IPv6
Deserializer function for IPv6 packets.
deserializer() - Static method in class org.onlab.packet.ipv6.EncapSecurityPayload
Deserializer function for encapsulated security payload headers.
deserializer() - Static method in class org.onlab.packet.ipv6.Fragment
Deserializer function for fragment headers.
deserializer() - Static method in class org.onlab.packet.ipv6.Routing
Deserializer function for routing headers.
deserializer() - Static method in class org.onlab.packet.lacp.Lacp
Deserializer function for LACP packets.
deserializer() - Static method in class org.onlab.packet.lacp.LacpBaseTlv
Deserializer function for LacpBaseTlv packets.
deserializer() - Static method in class org.onlab.packet.lacp.LacpCollectorTlv
Deserializer function for LacpCollectorTlv packets.
deserializer() - Static method in class org.onlab.packet.lacp.LacpTerminatorTlv
Deserializer function for LacpTerminatorTlv packets.
deserializer() - Static method in class org.onlab.packet.LLC
Deserializer function for LLC packets.
deserializer() - Static method in class org.onlab.packet.LLDP
Deserializer function for LLDP packets.
deserializer() - Static method in class org.onlab.packet.MPLS
Deserializer function for MPLS packets.
deserializer() - Static method in class org.onlab.packet.ndp.NeighborAdvertisement
Deserializer function for neighbor advertisement packets.
deserializer() - Static method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
deserializer() - Static method in class org.onlab.packet.ndp.NeighborSolicitation
Deserializer function for neighbor solicitation packets.
deserializer() - Static method in class org.onlab.packet.ndp.Redirect
Deserializer function for redirect packets.
deserializer() - Static method in class org.onlab.packet.ndp.RouterAdvertisement
Deserializer function for router advertisement packets.
deserializer() - Static method in class org.onlab.packet.ndp.RouterSolicitation
Deserializer function for router solicitation packets.
deserializer() - Static method in class org.onlab.packet.PIM
Deserializer function for IPv4 packets.
deserializer() - Static method in class org.onlab.packet.pim.PIMHello
Deserialize this hello message.
deserializer() - Static method in class org.onlab.packet.pim.PIMJoinPrune
Return the J/P deserializer function.
deserializer() - Static method in class org.onlab.packet.PPPoED
Deserializer for PPPoED packets.
deserializer() - Static method in class org.onlab.packet.RADIUS
Deserializer for RADIUS packets.
deserializer() - Static method in class org.onlab.packet.RIP
Deserializer function for RIP packets.
deserializer() - Static method in class org.onlab.packet.RIPng
Deserializer function for RIPng packets.
deserializer() - Static method in class org.onlab.packet.RIPngEntry
Deserializer function for RIPng entry.
deserializer() - Static method in class org.onlab.packet.RIPV2AuthEntry
Deserializer function for RIPv2 entry.
deserializer() - Static method in class org.onlab.packet.RIPV2Entry
Deserializer function for RIPv2 entry.
deserializer() - Static method in class org.onlab.packet.Slow
Deserializer function for Slow packets.
deserializer() - Static method in class org.onlab.packet.TCP
Deserializer function for TCP packets.
deserializer() - Static method in class org.onlab.packet.UDP
Deserializer function for UDP packets.
deserializer() - Static method in class org.onlab.packet.VXLAN
Returns the deserializer closure (used by upper layer deserializer).
Deserializer<U extends IPacket> - Interface in org.onlab.packet
Function to deserialize a packet from a byte-based input stream.
DEST - org.onosproject.cli.net.ExtHeader
Destination header.
DEST - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
1 or 2 dest headers present.
DEST_UNREACH - org.onosproject.cli.net.Icmp6Type
Destination Unreachable.
DEST_UNREACH - Static variable in class org.onlab.packet.ICMP6
Destination Unreachable.
destinationAddress - Variable in class org.onlab.packet.IPv4
 
destinationAddress - Variable in class org.onlab.packet.IPv6
 
destinationAddress - Variable in class org.onlab.packet.ndp.Redirect
 
destinationMACAddress - Variable in class org.onlab.packet.Ethernet
 
DestinationOptions - Class in org.onlab.packet.ipv6
Implements IPv6 Destination Options extension header format.
DestinationOptions() - Constructor for class org.onlab.packet.ipv6.DestinationOptions
 
destinationPort - Variable in class org.onlab.packet.TCP
 
destinationPort - Variable in class org.onlab.packet.UDP
 
destroy() - Method in class org.onlab.util.SlidingWindowCounter
Releases resources used by the SlidingWindowCounter.
destroy() - Method in interface org.onosproject.store.service.AsyncConsistentMap
 
destroy() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
 
destroy() - Method in interface org.onosproject.store.service.DistributedPrimitive
Purges state associated with this primitive.
destroy() - Method in class org.onosproject.store.service.Synchronous
 
destroy() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
 
destroy() - Method in class org.onosproject.ui.model.topo.UiElement
Removes all external references, and prepares the instance for garbage collection.
destroy() - Method in class org.onosproject.ui.model.topo.UiRegion
 
destroy() - Method in class org.onosproject.ui.UiMessageHandler
Destroys the message handler context.
destroy() - Method in class org.onosproject.ui.UiTopo2Overlay
Callback invoked to destroy this instance by cleaning up any internal state ready for garbage collection.
destroy() - Method in class org.onosproject.ui.UiTopoOverlay
Callback invoked to destroy this instance by cleaning up any internal state ready for garbage collection.
detachBackingLink(Link) - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Detaches the given backing link from this UI link, returning true if the reverse link is still attached, or false otherwise.
detailIntents(List<String>) - Method in class org.onosproject.cli.net.IntentDetailsCommand
Print detailed data for intents, given a list of IDs.
DETAILS - Static variable in class org.onosproject.ui.GlyphConstants
 
device() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a device service implementation.
device() - Method in class org.onosproject.ui.model.topo.UiRegionDeviceLink
Returns the identity of the device.
Device - Interface in org.onosproject.net
Representation of a network infrastructure device.
DEVICE - org.onosproject.ui.topo.TopoElementType
 
DEVICE_ADDED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a new device has been detected.
DEVICE_ADDED_OR_UPDATED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
DEVICE_AVAILABILITY_CHANGED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a device has come online or has gone offline.
DEVICE_DEVICE - org.onosproject.ui.model.topo.UiLinkId.Type
 
DEVICE_EVENT - org.onosproject.security.AppPermission.Type
 
DEVICE_KEY_ADDED - org.onosproject.net.key.DeviceKeyEvent.Type
Signals that a new device key has been added.
DEVICE_KEY_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
DEVICE_KEY_EVENT - org.onosproject.security.AppPermission.Type
 
DEVICE_KEY_READ - org.onosproject.security.AppPermission.Type
 
DEVICE_KEY_REMOVED - org.onosproject.net.key.DeviceKeyEvent.Type
Signals that a device key has been removed.
DEVICE_KEY_UPDATED - org.onosproject.net.key.DeviceKeyEvent.Type
Signals that a device key has been updated or changed state.
DEVICE_KEY_WRITE - org.onosproject.security.AppPermission.Type
 
DEVICE_READ - org.onosproject.security.AppPermission.Type
 
DEVICE_REMOVED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a device has been removed.
DEVICE_REMOVED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
DEVICE_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
Device ID subject factory.
DEVICE_SUBTYPE - Static variable in class org.onlab.packet.ONOSLLDP
 
DEVICE_SUSPENDED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a device has been administratively suspended.
DEVICE_UPDATED - org.onosproject.net.device.DeviceEvent.Type
Signifies that some device attributes have changed; excludes availability changes.
Device.Type - Enum in org.onosproject.net
Coarse classification of the type of the infrastructure device.
deviceA() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Returns the identity of device A.
DeviceAdminService - Interface in org.onosproject.net.device
Service for administering the inventory of infrastructure devices.
DeviceAgentEvent - Class in org.onosproject.net.device
Describes and event related to a protocol agent used to interact with an infrastructure device.
DeviceAgentEvent(DeviceAgentEvent.Type, DeviceId) - Constructor for class org.onosproject.net.device.DeviceAgentEvent
Creates a new device agent event for the given type and device ID.
DeviceAgentEvent.Type - Enum in org.onosproject.net.device
Type of device events.
DeviceAgentListener - Interface in org.onosproject.net.device
A listener to receive events related to a protocol agent controlling an infrastructure device.
DeviceAlarmConfig - Interface in org.onosproject.alarm
Abstraction of a device behaviour capable of translating a list of alarms from a device.
DeviceAnnotationConfig - Class in org.onosproject.net.config.basics
Configuration to add extra annotations to a device via netcfg subsystem.
DeviceAnnotationConfig() - Constructor for class org.onosproject.net.config.basics.DeviceAnnotationConfig
Create a detached DeviceAnnotationConfig.
DeviceAnnotationConfig(DeviceId) - Constructor for class org.onosproject.net.config.basics.DeviceAnnotationConfig
Create a detached DeviceAnnotationConfig for specified device.
deviceB() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Returns the identity of device B.
DeviceClockService - Interface in org.onosproject.net.device
Interface for a logical clock service that vends per device timestamps.
DeviceConfigOperator - Interface in org.onosproject.net.config
ConfigOperator for Device.
DeviceConnect - Interface in org.onosproject.net.driver
Abstraction of handler behaviour used to set-up and tear-down connections with a device.
deviceConnected(DeviceId, DeviceDescription) - Method in interface org.onosproject.net.device.DeviceProviderService
Signals the core that a device has connected or has been detected somehow.
deviceConnectPoint(String) - Static method in class org.onosproject.net.ConnectPoint
Parse a device connect point from a string.
DeviceControllersCommand - Class in org.onosproject.cli.net
Sets role of the controller node for the given infrastructure device.
DeviceControllersCommand() - Constructor for class org.onosproject.cli.net.DeviceControllersCommand
 
deviceCount() - Method in class org.onosproject.common.DefaultTopology
 
deviceCount() - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
deviceCount() - Method in interface org.onosproject.net.topology.Topology
Returns the number of infrastructure devices in the topology.
deviceCount() - Method in interface org.onosproject.net.topology.TopologyCluster
Returns the number of devices in the cluster.
deviceCount() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the count of devices in this region.
deviceCount() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the number of devices configured in the topology.
DeviceCpuStats - Class in org.onosproject.net.behaviour
A representation of cpu stats of device.
DeviceCpuStats() - Constructor for class org.onosproject.net.behaviour.DeviceCpuStats
Instantiates DeviceCpuStats object with default value.
DeviceCpuStats(float) - Constructor for class org.onosproject.net.behaviour.DeviceCpuStats
Creates DeviceCpuStats object with given value.
DeviceDescription - Interface in org.onosproject.net.device
Carrier of immutable information about a device.
DeviceDescriptionDiscovery - Interface in org.onosproject.net.device
Handler behaviour capable of creating device and port descriptions.
deviceDetails(DeviceId) - Method in interface org.onosproject.net.behaviour.DevicesDiscovery
Returns a device description appropriately annotated to support downstream model extension via projections of the resulting device, as in the following example.
deviceDisconnected(DeviceId) - Method in interface org.onosproject.net.device.DeviceProviderService
Signals the core that a device has disconnected or is no longer reachable.
DeviceDriverData() - Constructor for class org.onosproject.net.DefaultDevice.DeviceDriverData
 
DeviceDriversCommand - Class in org.onosproject.cli.net
 
DeviceDriversCommand() - Constructor for class org.onosproject.cli.net.DeviceDriversCommand
 
DeviceEvent - Class in org.onosproject.net.device
Describes infrastructure device event.
DeviceEvent(DeviceEvent.Type, Device) - Constructor for class org.onosproject.net.device.DeviceEvent
Creates an event of a given type and for the specified device and the current time.
DeviceEvent(DeviceEvent.Type, Device, Port) - Constructor for class org.onosproject.net.device.DeviceEvent
Creates an event of a given type and for the specified device, port and the current time.
DeviceEvent(DeviceEvent.Type, Device, Port, long) - Constructor for class org.onosproject.net.device.DeviceEvent
Creates an event of a given type and for the specified device and time.
DeviceEvent.Type - Enum in org.onosproject.net.device
Type of device events.
DeviceHandshaker - Interface in org.onosproject.net.device
Behavior to test device's reachability and change the mastership role on that device.
DeviceHighlight - Class in org.onosproject.ui.topo
Denotes the highlighting to be applied to a device.
DeviceHighlight(String) - Constructor for class org.onosproject.ui.topo.DeviceHighlight
Constructs a device highlight entity.
deviceId() - Method in interface org.onosproject.alarm.Alarm
The device to which this alarm is related.
deviceId() - Method in class org.onosproject.alarm.DefaultAlarm
 
deviceId() - Method in interface org.onosproject.cpman.ControlMessage
Returns the device identification.
deviceId() - Method in class org.onosproject.cpman.DefaultControlMessage
 
deviceId() - Method in class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
 
deviceId() - Method in interface org.onosproject.net.behaviour.BridgeDescription
Returns OpenFlow device ID.
deviceId() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
 
deviceId() - Method in class org.onosproject.net.behaviour.DefaultPatchDescription
 
deviceId() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
deviceId() - Method in interface org.onosproject.net.behaviour.PatchDescription
Returns the identifier of the device where this patch interface is.
deviceId() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
deviceId() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
The device of this policer, where policing is applied.
deviceId() - Method in interface org.onosproject.net.behaviour.TunnelDescription
Returns the identifier of the device where the interface is.
deviceId() - Method in class org.onosproject.net.ConnectPoint
Returns the identifier of the infrastructure device if the connection point belongs to a network element which is indeed an infrastructure device.
deviceId() - Method in class org.onosproject.net.DefaultDevice.DeviceDriverData
 
deviceId() - Method in class org.onosproject.net.driver.DefaultDriverData
 
deviceId() - Method in interface org.onosproject.net.driver.DriverData
Returns the device identifier.
deviceId() - Method in class org.onosproject.net.flow.CompletedBatchOperation
 
deviceId() - Method in class org.onosproject.net.flow.criteria.ExtensionCriterion
Returns the device ID.
deviceId() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
deviceId() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
deviceId() - Method in interface org.onosproject.net.flow.FlowRule
Returns the identity of the device where this rule applies.
deviceId() - Method in class org.onosproject.net.flow.instructions.Instructions.ExtensionInstructionWrapper
 
deviceId() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent
Deprecated.
Returns the deviceId for this batch.
deviceId() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchOperation
Deprecated.
 
deviceId() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
Returns the device Id.
deviceId() - Method in class org.onosproject.net.group.DefaultGroupDescription
Returns device identifier on which this group object is created.
deviceId() - Method in interface org.onosproject.net.group.GroupDescription
Returns device identifier on which this group object is created.
deviceId() - Method in class org.onosproject.net.intent.ProtectionEndpointIntent
Returns the identifier of the device to be configured.
deviceId() - Method in class org.onosproject.net.meter.DefaultMeter
 
deviceId() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
deviceId() - Method in class org.onosproject.net.meter.DefaultMeterRequest
 
deviceId() - Method in interface org.onosproject.net.meter.Meter
The target device for this meter.
deviceId() - Method in interface org.onosproject.net.meter.MeterFeatures
Return the device id to which this meter features apply.
deviceId() - Method in class org.onosproject.net.meter.MeterFeaturesKey
Deprecated.
 
deviceId() - Method in class org.onosproject.net.meter.MeterKey
 
deviceId() - Method in interface org.onosproject.net.meter.MeterRequest
The target device for this meter.
deviceId() - Method in class org.onosproject.net.meter.MeterTableKey
 
deviceId() - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
deviceId() - Method in interface org.onosproject.net.packet.PacketRequest
Obtains the optional device id.
deviceId() - Method in class org.onosproject.net.pi.runtime.PiHandle
Returns the device ID of this handle.
deviceId() - Method in class org.onosproject.net.topology.DefaultTopologyVertex
 
deviceId() - Method in interface org.onosproject.net.topology.TopologyVertex
Returns the associated infrastructure device identification.
deviceId() - Method in class org.onosproject.routing.RouterInfo
Returns the router device ID.
deviceId() - Method in class org.onosproject.ui.model.topo.UiEdgeLink
Returns the edge device identifier.
deviceId(String) - Method in class org.onosproject.net.behaviour.DefaultPatchDescription.Builder
 
deviceId(String) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
deviceId(String) - Method in interface org.onosproject.net.behaviour.PatchDescription.Builder
Returns new patch interface description.
deviceId(String) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface description biulder with supplied device ID.
deviceId(String) - Static method in class org.onosproject.net.DeviceId
Creates a device id using the supplied URI string.
deviceId(URI) - Static method in class org.onosproject.net.DeviceId
Creates a device id using the supplied URI.
deviceId(DeviceId) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
 
DeviceId - Class in org.onosproject.net
Immutable representation of a device identity.
DeviceId() - Constructor for class org.onosproject.net.DeviceId
 
DeviceIdCompleter - Class in org.onosproject.cli.net
Device ID completer.
DeviceIdCompleter() - Constructor for class org.onosproject.cli.net.DeviceIdCompleter
 
deviceIds() - Method in interface org.onosproject.net.behaviour.DevicesDiscovery
Returns a set of proxied device ids.
deviceIds() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the set of device identifiers for this region.
deviceIdSerializer() - Static method in class org.onosproject.store.serializers.DeviceIdSerializer
 
DeviceIdSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for DeviceId.
DeviceIdSerializer() - Constructor for class org.onosproject.store.serializers.DeviceIdSerializer
Creates DeviceId serializer instance.
deviceInitialAuditCompleted(DeviceId, boolean) - Method in interface org.onosproject.net.group.GroupStore
Indicates the first group audit is completed.
deviceInitialAuditStatus(DeviceId) - Method in interface org.onosproject.net.group.GroupStore
Retrieves the initial group audit status for a device.
DeviceInjectionConfig - Class in org.onosproject.net.config.inject
Config to inject a Device.
DeviceInjectionConfig() - Constructor for class org.onosproject.net.config.inject.DeviceInjectionConfig
DeviceInjectionConfig(DeviceId) - Constructor for class org.onosproject.net.config.inject.DeviceInjectionConfig
Create a DeviceInjectionConfig for specified Device.
DeviceInterfaceAddCommand - Class in org.onosproject.cli.net
Configures a device interface.
DeviceInterfaceAddCommand() - Constructor for class org.onosproject.cli.net.DeviceInterfaceAddCommand
 
DeviceInterfaceDescription - Interface in org.onosproject.net.device
The description of an interface used for legacy devices.
DeviceInterfaceDescription.Mode - Enum in org.onosproject.net.device
Represents the type of operation of the interface.
DeviceInterfaceRemoveCommand - Class in org.onosproject.cli.net
Removes an interface configurion from a device.
DeviceInterfaceRemoveCommand() - Constructor for class org.onosproject.cli.net.DeviceInterfaceRemoveCommand
 
DeviceInterfacesListCommand - Class in org.onosproject.cli.net
Lists all interfaces or interfaces of a device.
DeviceInterfacesListCommand() - Constructor for class org.onosproject.cli.net.DeviceInterfacesListCommand
 
DeviceKey - Class in org.onosproject.net.key
Abstraction of a device key.
DeviceKey.Type - Enum in org.onosproject.net.key
type of the device key.
DeviceKeyAddCommand - Class in org.onosproject.cli.net
Adds a device key.
DeviceKeyAddCommand() - Constructor for class org.onosproject.cli.net.DeviceKeyAddCommand
 
DeviceKeyAdminService - Interface in org.onosproject.net.key
Service for managing device keys.
DeviceKeyEvent - Class in org.onosproject.net.key
Describes device key events.
DeviceKeyEvent(DeviceKeyEvent.Type, DeviceKey) - Constructor for class org.onosproject.net.key.DeviceKeyEvent
Creates an event of a given type, and for the specified device key.
DeviceKeyEvent(DeviceKeyEvent.Type, DeviceKey, long) - Constructor for class org.onosproject.net.key.DeviceKeyEvent
Creates an event of a given type, for the specified device key, and the current time.
DeviceKeyEvent.Type - Enum in org.onosproject.net.key
Type of device key events.
deviceKeyId() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device key id.
deviceKeyId() - Method in class org.onosproject.net.key.DeviceKey
Returns the device key identifier of the device key.
deviceKeyId(String) - Static method in class org.onosproject.net.key.DeviceKeyId
Creates a new device key identifier.
deviceKeyId(DeviceKeyId) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device key id.
DeviceKeyId - Class in org.onosproject.net.key
Device key identifier backed by a string value.
DeviceKeyListCommand - Class in org.onosproject.cli.net
Lists all device keys.
DeviceKeyListCommand() - Constructor for class org.onosproject.cli.net.DeviceKeyListCommand
 
DeviceKeyListener - Interface in org.onosproject.net.key
Listener for device key related events.
DeviceKeyRemoveCommand - Class in org.onosproject.cli.net
Removes a device key.
DeviceKeyRemoveCommand() - Constructor for class org.onosproject.cli.net.DeviceKeyRemoveCommand
 
DeviceKeyService - Interface in org.onosproject.net.key
Service for querying device keys.
DeviceKeyStore - Interface in org.onosproject.net.key
Manages inventory of device keys; not intended for direct use.
DeviceKeyStoreDelegate - Interface in org.onosproject.net.key
Device key store delegate abstraction.
deviceLinkCount() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the number of device links configured in the topology.
DeviceListener - Interface in org.onosproject.net.device
Entity capable of receiving infrastructure device related events.
DeviceMemoryStats - Class in org.onosproject.net.behaviour
A representation of memory stats of device.
DeviceMemoryStats() - Constructor for class org.onosproject.net.behaviour.DeviceMemoryStats
Instantiates DeviceMemoryStats object.
DeviceMemoryStats(long, long, long) - Constructor for class org.onosproject.net.behaviour.DeviceMemoryStats
Creates DeviceMemoryStats object with given data.
DEVICEMISSING - org.onosproject.net.flowobjective.ObjectiveError
The device was not available to install objectives to.
DevicePortsListCommand - Class in org.onosproject.cli.net
Lists all ports or all ports of a device.
DevicePortsListCommand() - Constructor for class org.onosproject.cli.net.DevicePortsListCommand
 
DevicePortsRemoveCommand - Class in org.onosproject.cli.net
Removes an infrastructure device.
DevicePortsRemoveCommand() - Constructor for class org.onosproject.cli.net.DevicePortsRemoveCommand
 
DevicePortStateCommand - Class in org.onosproject.cli.net
Administratively enables or disabled a port on a device.
DevicePortStateCommand() - Constructor for class org.onosproject.cli.net.DevicePortStateCommand
 
DevicePortStatsCommand - Class in org.onosproject.cli.net
Lists port statistic of all ports in the system.
DevicePortStatsCommand() - Constructor for class org.onosproject.cli.net.DevicePortStatsCommand
 
DeviceProvider - Interface in org.onosproject.net.device
Abstraction of a device information provider.
DeviceProviderRegistry - Interface in org.onosproject.net.device
Abstraction of a device provider registry.
DeviceProviderService - Interface in org.onosproject.net.device
Service through which device providers can inject device information into the core.
DeviceRebootCommand - Class in org.onosproject.cli.net
Administratively reboots device.
DeviceRebootCommand() - Constructor for class org.onosproject.cli.net.DeviceRebootCommand
 
DeviceRemoveCommand - Class in org.onosproject.cli.net
Removes an infrastructure device.
DeviceRemoveCommand() - Constructor for class org.onosproject.cli.net.DeviceRemoveCommand
 
deviceRemoved(DeviceId) - Method in class org.onosproject.ui.model.topo.UiRegion
 
DeviceRoleCommand - Class in org.onosproject.cli.net
Sets role of the controller node for the given infrastructure device.
DeviceRoleCommand() - Constructor for class org.onosproject.cli.net.DeviceRoleCommand
 
devices() - Method in class org.onosproject.net.config.basics.BasicRegionConfig
Returns the identities of the devices in this region.
devices() - Method in class org.onosproject.net.intent.FlowObjectiveIntent
Returns the list of devices for the flow objectives.
devices() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the devices in this region.
devices() - Method in class org.onosproject.ui.topo.Highlights
Returns the collection of device highlights.
devices() - Method in class org.onosproject.ui.topo.NodeSelection
Returns a view of the selected devices (hover not included).
devices(Set<DeviceId>) - Method in class org.onosproject.net.config.basics.BasicRegionConfig
Sets the devices of this region.
DEVICES - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
DevicesDiscovery - Interface in org.onosproject.net.behaviour
Handler behaviour capable of managing a set of forwarding plane devices.
DeviceService - Interface in org.onosproject.net.device
Service for interacting with the inventory of infrastructure devices.
DeviceServiceAdapter - Class in org.onosproject.net.device
Test adapter for device service.
DeviceServiceAdapter() - Constructor for class org.onosproject.net.device.DeviceServiceAdapter
Default constructor.
DeviceServiceAdapter(List<Port>) - Constructor for class org.onosproject.net.device.DeviceServiceAdapter
Constructor with port list.
DeviceSetControllersCommand - Class in org.onosproject.cli.net
Sets role of the controller node for the given infrastructure device.
DeviceSetControllersCommand() - Constructor for class org.onosproject.cli.net.DeviceSetControllersCommand
 
DevicesListCommand - Class in org.onosproject.cli.net
Lists all infrastructure devices.
DevicesListCommand() - Constructor for class org.onosproject.cli.net.DevicesListCommand
 
deviceState() - Method in class org.onosproject.net.PipelineTraceableInput
Getter for the device state.
DeviceStore - Interface in org.onosproject.net.device
Manages inventory of infrastructure devices; not intended for direct use.
DeviceStoreDelegate - Interface in org.onosproject.net.device
Infrastructure device store delegate abstraction.
devicesWithHover() - Method in class org.onosproject.ui.topo.NodeSelection
Returns a view of the selected devices, including the hovered device if there was one.
DeviceSystemStatisticsQuery - Interface in org.onosproject.net.behaviour
A HandlerBehaviour to get System Stats for the Device.
DeviceSystemStats - Class in org.onosproject.net.behaviour
A representation of system stats of device.
DeviceSystemStats(DeviceMemoryStats, DeviceCpuStats) - Constructor for class org.onosproject.net.behaviour.DeviceSystemStats
Creates deviceSystemStats object.
DeviceTimeCommand - Class in org.onosproject.cli.net
Gets time since epoch.
DeviceTimeCommand() - Constructor for class org.onosproject.cli.net.DeviceTimeCommand
 
deviceUri() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
deviceUri() - Method in interface org.onosproject.net.device.DeviceDescription
Protocol/provider specific URI that can be used to encode the identity information required to communicate with the device externally, e.g.
DFS_MESSAGE_HANDLER_THREAD_POOL_SIZE - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
DFS_MESSAGE_HANDLER_THREAD_POOL_SIZE_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
DHCP - Class in org.onlab.packet
Representation of an DHCP Packet.
DHCP() - Constructor for class org.onlab.packet.DHCP
 
DHCP_CLIENT_PORT - Static variable in class org.onlab.packet.UDP
 
DHCP_SERVER_PORT - Static variable in class org.onlab.packet.UDP
 
DHCP_V6_CLIENT_PORT - Static variable in class org.onlab.packet.UDP
 
DHCP_V6_SERVER_PORT - Static variable in class org.onlab.packet.UDP
 
DHCP.DHCPOptionCode - Enum in org.onlab.packet
 
DHCP.MsgType - Enum in org.onlab.packet
 
DHCP6 - Class in org.onlab.packet
Representation of an DHCPv6 Packet.
DHCP6() - Constructor for class org.onlab.packet.DHCP6
Creates new DHCPv6 object.
DHCP6.MsgType - Enum in org.onlab.packet
DHCPv6 message type.
DHCP6.OptionCode - Enum in org.onlab.packet
DHCPv6 option code.
Dhcp6ClientDataOption - Class in org.onlab.packet.dhcp
DHCPv6 Client Data Option.
Dhcp6ClientDataOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
Dhcp6ClientIdOption - Class in org.onlab.packet.dhcp
DHCPv6 Client Identifier Option.
Dhcp6ClientIdOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
Dhcp6CLTOption - Class in org.onlab.packet.dhcp
 
Dhcp6CLTOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6CLTOption
Default constructor.
Dhcp6CLTOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6CLTOption
Constructs a DHCPv6 Client Last Transaction Time option.
Dhcp6DirectPacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
Dhcp6DirectPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.Dhcp6DirectPacketClassifier
 
Dhcp6Duid - Class in org.onlab.packet.dhcp
 
Dhcp6Duid() - Constructor for class org.onlab.packet.dhcp.Dhcp6Duid
 
Dhcp6Duid.DuidType - Enum in org.onlab.packet.dhcp
 
Dhcp6IaAddressOption - Class in org.onlab.packet.dhcp
IA Address option for DHCPv6.
Dhcp6IaAddressOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
Dhcp6IaNaOption - Class in org.onlab.packet.dhcp
DHCPv6 Identity Association for Non-temporary Addresses Option.
Dhcp6IaNaOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6IaNaOption
Default constructor.
Dhcp6IaNaOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6IaNaOption
Constructs a DHCPv6 IA NA option with DHCPv6 option.
Dhcp6IaPdOption - Class in org.onlab.packet.dhcp
DHCPv6 Identity Association for Prefix Delegation Option.
Dhcp6IaPdOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6IaPdOption
Default constructor.
Dhcp6IaPdOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6IaPdOption
Constructs a DHCPv6 IA PD option with DHCPv6 option.
Dhcp6IaPrefixOption - Class in org.onlab.packet.dhcp
IA Address option for DHCPv6.
Dhcp6IaPrefixOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
Dhcp6IaTaOption - Class in org.onlab.packet.dhcp
 
Dhcp6IaTaOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6IaTaOption
Default constructor.
Dhcp6IaTaOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6IaTaOption
Constructs a DHCPv6 IA TA option with DHCPv6 option.
Dhcp6IndirectPacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
Dhcp6IndirectPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.Dhcp6IndirectPacketClassifier
 
Dhcp6InterfaceIdOption - Class in org.onlab.packet.dhcp
Relay option for DHCPv6.
Dhcp6InterfaceIdOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Default constructor.
Dhcp6InterfaceIdOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Constructs a DHCPv6 relay option with DHCPv6 option.
Dhcp6LeaseQueryOption - Class in org.onlab.packet.dhcp
DHCPv6 Lease Query Option.
Dhcp6LeaseQueryOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
Dhcp6Option - Class in org.onlab.packet.dhcp
Representation of an DHCPv6 Option.
Dhcp6Option() - Constructor for class org.onlab.packet.dhcp.Dhcp6Option
Default constructor.
Dhcp6Option(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6Option
Constructs a DHCPv6 option based on information from other DHCPv6 option.
Dhcp6RelayOption - Class in org.onlab.packet.dhcp
Relay option for DHCPv6.
Dhcp6RelayOption() - Constructor for class org.onlab.packet.dhcp.Dhcp6RelayOption
Default constructor.
Dhcp6RelayOption(Dhcp6Option) - Constructor for class org.onlab.packet.dhcp.Dhcp6RelayOption
Constructs a DHCPv6 relay option with DHCPv6 option.
DHCPACK - org.onlab.packet.DHCP.MsgType
 
DHCPDECLINE - org.onlab.packet.DHCP.MsgType
 
DHCPDISCOVER - org.onlab.packet.DHCP.MsgType
 
DHCPFORCERENEW - org.onlab.packet.DHCP.MsgType
 
DHCPINFORM - org.onlab.packet.DHCP.MsgType
 
DHCPLEASEACTIVE - org.onlab.packet.DHCP.MsgType
 
DHCPLEASEQUERY - org.onlab.packet.DHCP.MsgType
 
DHCPLEASEUNASSIGNED - org.onlab.packet.DHCP.MsgType
 
DHCPLEASEUNKNOWN - org.onlab.packet.DHCP.MsgType
 
DHCPNAK - org.onlab.packet.DHCP.MsgType
 
DHCPOFFER - org.onlab.packet.DHCP.MsgType
 
DhcpOption - Class in org.onlab.packet.dhcp
Default DHCP option.
DhcpOption() - Constructor for class org.onlab.packet.dhcp.DhcpOption
 
DhcpPacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
DhcpPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.DhcpPacketClassifier
 
DhcpRelayAgentOption - Class in org.onlab.packet.dhcp
Representation of DHCP relay agent option (option 82).
DhcpRelayAgentOption() - Constructor for class org.onlab.packet.dhcp.DhcpRelayAgentOption
 
DhcpRelayAgentOption.RelayAgentInfoOptions - Enum in org.onlab.packet.dhcp
 
DHCPRELEASE - org.onlab.packet.DHCP.MsgType
 
DHCPREQUEST - org.onlab.packet.DHCP.MsgType
 
dhcpServer() - Method in class org.onosproject.dhcp.IpAssignment
Returns dhcp server of the IP assignment.
dhcpServer(Ip4Address) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
DhcpService - Interface in org.onosproject.dhcp
DHCP Service Interface.
DhcpStore - Interface in org.onosproject.dhcp
DHCPStore Interface.
diffServ - Variable in class org.onlab.packet.IPv4
 
DijkstraGraphSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Dijkstra shortest-path graph search algorithm capable of finding not just one, but all shortest paths between the source and destinations.
DijkstraGraphSearch() - Constructor for class org.onlab.graph.DijkstraGraphSearch
 
DIRECT - org.onosproject.net.Link.Type
Signifies that this is a direct single-segment link.
DIRECT - org.onosproject.net.pi.model.PiCounterType
Identifies a counter associated to a match-action table, where cells are directly associated to table entries.
DIRECT - org.onosproject.net.pi.model.PiMeterType
Identifies a meter associated to a match-action table, where meter cells are directly associated to table entries.
DIRECT - org.onosproject.net.pi.model.PiTableType
Regular match+action table.
Direction - Enum in org.onosproject.net
Represents a direction.
director(int) - Static method in interface org.onosproject.net.packet.PacketProcessor
Returns a priority in the DIRECTOR range, where processors can handle the packet.
DIRECTOR_MAX - Static variable in interface org.onosproject.net.packet.PacketProcessor
 
directory() - Method in interface org.onosproject.net.behaviour.PipelinerContext
Returns the service directory which can be used to obtain references to various supporting services.
directory() - Method in class org.onosproject.ui.UiMessageHandler
Returns the service directory with which this handler was primed.
disable(PortNumber) - Method in interface org.onosproject.net.behaviour.PortAdmin
Disable administratively a port.
disableForTests() - Static method in class org.onlab.rest.AuthorizationFilter
 
disableInBand() - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
Returns bridge description builder with in-band control disabled.
disableInBand() - Method in interface org.onosproject.net.behaviour.BridgeDescription
Returns in band control is enabled or not.
disableInBand() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
 
disableInBand() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
 
disablePscEncap() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Disable PSC encap previously enabled with UpfDevice.enablePscEncap(int).
disableVlan(Collection<VlanId>) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Disables VLANs on a device.
disableVlan(VlanId) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Disables a VLAN on a device.
DISCARD - org.onosproject.net.behaviour.BandwidthProfileAction.Action
Traffic is dropped.
disconnect() - Method in interface org.onosproject.net.driver.DeviceConnect
Disconnects from the device, for example closing any transport session previously opened.
DISCOVER - org.onosproject.net.host.ProbeMode
Append probed host location if reply is received before timeout.
discoverDevice(DriverHandler) - Method in class org.onosproject.common.net.AbstractDeviceProvider
Discovers the device details using the device discovery behaviour of the supplied driver handler context for interacting with a specific device.
discoverDeviceDetails() - Method in interface org.onosproject.net.device.DeviceDescriptionDiscovery
Returns a device description appropriately annotated to support downstream model extension via projections of the resulting device, as in the following example.
discoverPortDetails() - Method in interface org.onosproject.net.device.DeviceDescriptionDiscovery
Returns a list of port descriptions appropriately annotated to support downstream model extension via projections of their parent device, as in the following example.
discoverPortDetails(Consumer<PortDescription>) - Method in interface org.onosproject.net.device.DeviceDescriptionDiscovery
Invoke given lamda function when port descriptions are discovered.
discoverPortStatistics() - Method in interface org.onosproject.net.device.PortStatisticsDiscovery
Returns a list of port statistics descriptions appropriately annotated to support downstream model extension via projections of their parent device.
discrete(DeviceId) - Static method in class org.onosproject.net.resource.Resources
Create a factory for discrete-type with the specified device ID.
discrete(DeviceId, Object...) - Static method in class org.onosproject.net.resource.Resources
Create a factory for discrete-type with the specified device ID and components.
discrete(DeviceId, PortNumber, Object...) - Static method in class org.onosproject.net.resource.Resources
Create a factory for discrete-type with the specified device ID, port number and components.
discrete(DiscreteResourceId) - Static method in class org.onosproject.net.resource.Resources
Create a factory for discrete-type with the specified resource ID.
discrete(DiscreteResourceId, Object) - Static method in class org.onosproject.net.resource.Resources
Creates a factory for discrete-type with the specified parent ID and child.
DiscreteFactory - Class in org.onosproject.net.resource
Factory class for discrete-type resource related instances.
DiscreteResource - Class in org.onosproject.net.resource
Represents a resource path which specifies a resource which can be measured as a discrete unit.
DiscreteResourceCodec<T> - Interface in org.onosproject.net.resource
Represents the common interface to encode an object of the specified type to an integer, and to decode an integer to an object of the specified type.
DiscreteResourceId - Class in org.onosproject.net.resource
ResourceId for DiscreteResource.
DisjointPath - Interface in org.onosproject.net
Representation of a contiguous directed path in a network.
DisjointPathPair<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Pair of disjoint paths.
DisjointPathPair(Path<V, E>, Path<V, E>) - Constructor for class org.onlab.graph.DisjointPathPair
Creates a disjoint path pair from two paths.
DISK - org.onosproject.cpman.ControlResource.Type
 
DISK_METRICS - Static variable in class org.onosproject.cpman.ControlResource
 
DISK_READ_BYTES - org.onosproject.cpman.ControlMetricType
 
DISK_WRITE_BYTES - org.onosproject.cpman.ControlMetricType
 
DISTRIBUTED_AN_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
DistributedApplicationStore - Class in org.onosproject.store.app
Manages inventory of applications in a distributed data store providing stronger consistency guarantees.
DistributedApplicationStore() - Constructor for class org.onosproject.store.app.DistributedApplicationStore
 
DistributedApplicationStore.InternalState - Enum in org.onosproject.store.app
 
DistributedComponentConfigStore - Class in org.onosproject.store.cfg
Manages inventory of component configurations in a distributed data store that provides strong sequential consistency guarantees.
DistributedComponentConfigStore() - Constructor for class org.onosproject.store.cfg.DistributedComponentConfigStore
 
DistributedLock - Interface in org.onosproject.store.service
Asynchronous lock primitive.
DistributedLockBuilder - Class in org.onosproject.store.service
Builder for DistributedLock.
DistributedLockBuilder() - Constructor for class org.onosproject.store.service.DistributedLockBuilder
 
DistributedLockOptions<O extends DistributedLockOptions<O>> - Class in org.onosproject.store.service
Builder for DistributedLock.
DistributedLockOptions() - Constructor for class org.onosproject.store.service.DistributedLockOptions
 
DistributedPrimitive - Interface in org.onosproject.store.service
Interface for all distributed primitives.
DistributedPrimitive.Status - Enum in org.onosproject.store.service
Status of distributed primitive.
DistributedPrimitive.Type - Enum in org.onosproject.store.service
Type of distributed primitive.
DistributedPrimitiveBuilder<T extends DistributedPrimitive> - Interface in org.onosproject.store.primitives
Abstract builder for distributed primitives.
DistributedPrimitiveCreator - Interface in org.onosproject.store.primitives
Interface for entity that can create instances of different distributed primitives.
DistributedPrimitiveOptions<O extends DistributedPrimitiveOptions<O>> - Class in org.onosproject.store.primitives
Abstract builder for distributed primitives.
DistributedPrimitiveOptions(DistributedPrimitive.Type) - Constructor for class org.onosproject.store.primitives.DistributedPrimitiveOptions
 
DistributedSet<E> - Interface in org.onosproject.store.service
A distributed collection designed for holding unique elements.
DistributedSetBuilder<E> - Class in org.onosproject.store.service
Builder for distributed set.
DistributedSetBuilder() - Constructor for class org.onosproject.store.service.DistributedSetBuilder
 
DistributedSetOptions<O extends DistributedSetOptions<O,​E>,​E> - Class in org.onosproject.store.service
Builder for distributed set.
DistributedSetOptions() - Constructor for class org.onosproject.store.service.DistributedSetOptions
 
DistributedStoreSerializers - Class in org.onosproject.store.serializers.custom
 
DO_NOT_TRUNCATE - Static variable in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
docs() - Method in class org.onosproject.rest.ApiDocProvider
Returns input stream containing Swagger UI compatible JSON.
DOCSIS - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
DOCUMENT_TREE - org.onosproject.store.service.DistributedPrimitive.Type
Document tree.
DocumentException - Exception in org.onosproject.store.service
Exceptions for use by the DocumentTree and DocumentPath.
DocumentException() - Constructor for exception org.onosproject.store.service.DocumentException
 
DocumentException(String) - Constructor for exception org.onosproject.store.service.DocumentException
 
DocumentException(String, Throwable) - Constructor for exception org.onosproject.store.service.DocumentException
 
DocumentException(Throwable) - Constructor for exception org.onosproject.store.service.DocumentException
 
DocumentException.Interrupted - Exception in org.onosproject.store.service
DocumentTree operation interrupted.
DocumentException.Timeout - Exception in org.onosproject.store.service
DocumentTree operation timeout.
DocumentPath - Class in org.onosproject.store.service
Unique key for nodes in the DocumentTree.
DocumentPath(String, DocumentPath) - Constructor for class org.onosproject.store.service.DocumentPath
Constructs a new document path.
DocumentTree<V> - Interface in org.onosproject.store.service
A hierarchical document tree data structure.
documentTreeBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new ConsistentMapBuilder.
documentTreeBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new ConsistentMapBuilder.
DocumentTreeBuilder<V> - Class in org.onosproject.store.service
Builder for DocumentTree.
DocumentTreeBuilder() - Constructor for class org.onosproject.store.service.DocumentTreeBuilder
 
DocumentTreeEvent<V> - Class in org.onosproject.store.service
A document tree modification event.
DocumentTreeEvent(DocumentPath, Optional<Versioned<V>>, Optional<Versioned<V>>) - Constructor for class org.onosproject.store.service.DocumentTreeEvent
Constructs a new DocumentTreeEvent.
DocumentTreeEvent(DocumentPath, DocumentTreeEvent.Type, Optional<Versioned<V>>, Optional<Versioned<V>>) - Constructor for class org.onosproject.store.service.DocumentTreeEvent
Constructs a new DocumentTreeEvent.
DocumentTreeEvent.Type - Enum in org.onosproject.store.service
Nature of document tree node change.
DocumentTreeListener<V> - Interface in org.onosproject.store.service
A listener for DocumentTreeEvent.
DocumentTreeNode<V> - Interface in org.onosproject.store.service
A DocumentTree node.
DocumentTreeOptions<O extends DocumentTreeOptions<O,​V>,​V> - Class in org.onosproject.store.service
Builder for DocumentTree.
DocumentTreeOptions() - Constructor for class org.onosproject.store.service.DocumentTreeOptions
 
doExecute() - Method in class org.onosproject.cli.AbstractShellCommand
Body of the shell command.
doExecute() - Method in class org.onosproject.cli.app.ApplicationCommand
 
doExecute() - Method in class org.onosproject.cli.app.ApplicationIdListCommand
 
doExecute() - Method in class org.onosproject.cli.app.ApplicationsListCommand
 
doExecute() - Method in class org.onosproject.cli.BalanceMastersCommand
 
doExecute() - Method in class org.onosproject.cli.cfg.ComponentConfigCommand
 
doExecute() - Method in class org.onosproject.cli.cfg.NetworkConfigCommand
 
doExecute() - Method in class org.onosproject.cli.cfg.NetworkConfigRegistryCommand
 
doExecute() - Method in class org.onosproject.cli.IssuCommand
 
doExecute() - Method in class org.onosproject.cli.MarkCommand
 
doExecute() - Method in class org.onosproject.cli.MastersListCommand
 
doExecute() - Method in class org.onosproject.cli.MembershipsListCommand
 
doExecute() - Method in class org.onosproject.cli.MetricsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.AddHostToHostIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.AddMultiPointToSinglePointIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.AddPointToPointIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.AddProtectedTransportIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.AddSinglePointToMultiPointIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.AddTestFlowsCommand
 
doExecute() - Method in class org.onosproject.cli.net.AllocationsCommand
 
doExecute() - Method in class org.onosproject.cli.net.AnnotateDeviceCommand
 
doExecute() - Method in class org.onosproject.cli.net.AnnotateHostCommand
 
doExecute() - Method in class org.onosproject.cli.net.AnnotateLinkCommand
 
doExecute() - Method in class org.onosproject.cli.net.AnnotatePortCommand
 
doExecute() - Method in class org.onosproject.cli.net.BitErrorCommand
 
doExecute() - Method in class org.onosproject.cli.net.ClusterDevicesCommand
 
doExecute() - Method in class org.onosproject.cli.net.ClusterLinksCommand
 
doExecute() - Method in class org.onosproject.cli.net.ClustersListCommand
 
doExecute() - Method in class org.onosproject.cli.net.ConfigureLinkCommand
 
doExecute() - Method in class org.onosproject.cli.net.CounterCommand
 
doExecute() - Method in class org.onosproject.cli.net.CountersListCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceControllersCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceDriversCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceInterfaceAddCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceInterfaceRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceInterfacesListCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceKeyAddCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceKeyListCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceKeyRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.DevicePortsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.DevicePortsRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.DevicePortStateCommand
 
doExecute() - Method in class org.onosproject.cli.net.DevicePortStatsCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceRebootCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceRoleCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceSetControllersCommand
 
doExecute() - Method in class org.onosproject.cli.net.DevicesListCommand
 
doExecute() - Method in class org.onosproject.cli.net.DeviceTimeCommand
 
doExecute() - Method in class org.onosproject.cli.net.DriverProvidersListCommand
 
doExecute() - Method in class org.onosproject.cli.net.DriversListCommand
 
doExecute() - Method in class org.onosproject.cli.net.EdgePortsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.FlowObjectiveCompositionCommand
 
doExecute() - Method in class org.onosproject.cli.net.FlowObjectiveNextListCommand
 
doExecute() - Method in class org.onosproject.cli.net.FlowObjectivePendingNextCommand
 
doExecute() - Method in class org.onosproject.cli.net.FlowObjectiveQueueClearCommand
 
doExecute() - Method in class org.onosproject.cli.net.FlowObjectiveQueueListCommand
 
doExecute() - Method in class org.onosproject.cli.net.FlowsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.GetDomainsCommand
 
doExecute() - Method in class org.onosproject.cli.net.GetFlowStatisticsCommand
 
doExecute() - Method in class org.onosproject.cli.net.GetInternalConnectivityOutputPortsCommand
 
doExecute() - Method in class org.onosproject.cli.net.GetStatisticsCommand
 
doExecute() - Method in class org.onosproject.cli.net.GroupsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.HostRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.HostsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentCycleCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentDetailsCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentListCompilers
 
doExecute() - Method in class org.onosproject.cli.net.IntentListInstallers
 
doExecute() - Method in class org.onosproject.cli.net.IntentPurgeCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentPushTestCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentsDiagnosisCommand
 
doExecute() - Method in class org.onosproject.cli.net.IntentsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.InterfaceAddCommand
 
doExecute() - Method in class org.onosproject.cli.net.InterfaceRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.InterfacesListCommand
 
doExecute() - Method in class org.onosproject.cli.net.InternalConnectivityCommand
 
doExecute() - Method in class org.onosproject.cli.net.LayoutAddCommand
 
doExecute() - Method in class org.onosproject.cli.net.LayoutListCommand
 
doExecute() - Method in class org.onosproject.cli.net.LeaderCommand
 
doExecute() - Method in class org.onosproject.cli.net.LinksListCommand
 
doExecute() - Method in class org.onosproject.cli.net.MapsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.McastDeleteCommand
 
doExecute() - Method in class org.onosproject.cli.net.McastJoinCommand
 
doExecute() - Method in class org.onosproject.cli.net.McastRoutesListCommand
 
doExecute() - Method in class org.onosproject.cli.net.McastShowCommand
 
doExecute() - Method in class org.onosproject.cli.net.MeterAddCommand
 
doExecute() - Method in class org.onosproject.cli.net.MeterRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.MetersListCommand
 
doExecute() - Method in class org.onosproject.cli.net.NeighbourHandlersListCommand
 
doExecute() - Method in class org.onosproject.cli.net.PacketProcessorsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.PacketRequestsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.PartitionsListCommand
 
doExecute() - Method in class org.onosproject.cli.net.PartitionsSnapshotCommand
 
doExecute() - Method in class org.onosproject.cli.net.PathListCommand
 
doExecute() - Method in class org.onosproject.cli.net.PipeconfCommand
 
doExecute() - Method in class org.onosproject.cli.net.PortQueryVlansCommand
 
doExecute() - Method in class org.onosproject.cli.net.PowerConfigCommand
 
doExecute() - Method in class org.onosproject.cli.net.QueuesListCommand
 
doExecute() - Method in class org.onosproject.cli.net.RandomIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionAddCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionAddDevicesCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionAddPeerLocCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionListCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionRemoveCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionRemoveDevicesCommand
 
doExecute() - Method in class org.onosproject.cli.net.RegionUpdateCommand
 
doExecute() - Method in class org.onosproject.cli.net.ResourcesCommand
 
doExecute() - Method in class org.onosproject.cli.net.TableStatisticsCommand
 
doExecute() - Method in class org.onosproject.cli.net.TestAllocateResource
 
doExecute() - Method in class org.onosproject.cli.net.TestProtectionEndpointIntentCommand
 
doExecute() - Method in class org.onosproject.cli.net.TopologyCommand
 
doExecute() - Method in class org.onosproject.cli.net.TransactionsCommand
 
doExecute() - Method in class org.onosproject.cli.net.WipeOutCommand
 
doExecute() - Method in class org.onosproject.cli.NodesListCommand
 
doExecute() - Method in class org.onosproject.cli.PrettyJson
 
doExecute() - Method in class org.onosproject.cli.PrettyXml
 
doExecute() - Method in class org.onosproject.cli.RolesCommand
 
doExecute() - Method in class org.onosproject.cli.ScrListCommand
 
doExecute() - Method in class org.onosproject.cli.security.ReviewCommand
 
doExecute() - Method in class org.onosproject.cli.StorageNodesListCommand
 
doExecute() - Method in class org.onosproject.cli.SummaryCommand
 
domain() - Static method in class org.onosproject.net.intent.constraint.DomainConstraint
Returns domain constraint.
DOMAIN_SUBTYPE - Static variable in class org.onlab.packet.ONOSLLDP
 
DomainConstraint - Class in org.onosproject.net.intent.constraint
This constraint is a flag and tells the compiler that it is allowed to generate DomainIntent.
DomainConstraint() - Constructor for class org.onosproject.net.intent.constraint.DomainConstraint
 
domainId(String) - Static method in class org.onosproject.net.domain.DomainId
Creates a peer id from the string identifier.
DomainId - Class in org.onosproject.net.domain
Representation of a domain identity.
DomainId(String) - Constructor for class org.onosproject.net.domain.DomainId
Constructor of the peer id.
DomainIdCompleter - Class in org.onosproject.cli.net
Domain ID completer.
DomainIdCompleter() - Constructor for class org.onosproject.cli.net.DomainIdCompleter
 
DomainIntent - Class in org.onosproject.net.domain
Intents targeting a domain network.
DomainIntent() - Constructor for class org.onosproject.net.domain.DomainIntent
Constructor for serializer.
DomainIntent(ApplicationId, Key, Collection<NetworkResource>, int, Set<FilteredConnectPoint>, Set<FilteredConnectPoint>, TrafficTreatment, List<Constraint>) - Constructor for class org.onosproject.net.domain.DomainIntent
 
DomainIntent.Builder - Class in org.onosproject.net.domain
Abstract builder for connectivity intents.
DomainIntentConfigurable - Interface in org.onosproject.net.behaviour
Behaviour to manages the intent in a network domain.
DomainIntentOperation - Class in org.onosproject.net.domain
Representation of an intent operation on a network domain.
DomainIntentOperation(DomainIntent, DomainIntentOperation.Type) - Constructor for class org.onosproject.net.domain.DomainIntentOperation
Creates a domain intent operation using the supplied information.
DomainIntentOperation.Type - Enum in org.onosproject.net.domain
Type of domain intent operations.
DomainIntentOperations - Class in org.onosproject.net.domain
A batch of domain intent operations that are broken into stages.
DomainIntentOperations() - Constructor for class org.onosproject.net.domain.DomainIntentOperations
 
DomainIntentOperations.Builder - Class in org.onosproject.net.domain
A builder for constructing domain intent operations.
DomainIntentOperationsContext - Interface in org.onosproject.net.domain
Represents domain intent that does nothing on success or on error.
DomainIntentService - Interface in org.onosproject.net.domain
Service used to submit and remove intent domains.
DomainPointToPointIntent - Class in org.onosproject.net.domain
Representation of a point to point intent targeting a domain.
DomainPointToPointIntent() - Constructor for class org.onosproject.net.domain.DomainPointToPointIntent
Constructor for serializer.
DomainPointToPointIntent.Builder - Class in org.onosproject.net.domain
Builder of a point to point domain intent.
domainServer() - Method in class org.onosproject.dhcp.IpAssignment
Returns domain server address.
domainServer(Ip4Address) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
DomainService - Interface in org.onosproject.net.domain
Service to access domain topology elements.
DOUBLE - org.onosproject.cfg.ConfigProperty.Type
Indicates the value is a double.
DOWN - Static variable in class org.onosproject.cli.UpDownCompleter
 
DOWNSTREAM_DROPPED - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Count the dropped packets in the downstream direction.
DOWNSTREAM_RX - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Count the received packets in the downstream direction.
DOWNSTREAM_TX - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Count the transmitted packets in the downstream direction.
DP_16QAM - org.onosproject.net.ModulationScheme
 
DP_8QAM - org.onosproject.net.ModulationScheme
 
DP_QPSK - org.onosproject.net.ModulationScheme
 
DPS_MESSAGE_HANDLER_THREAD_POOL_SIZE - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
DPS_MESSAGE_HANDLER_THREAD_POOL_SIZE_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
driver() - Method in class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
 
driver() - Method in class org.onosproject.net.AbstractProjectableModel
Returns the currently bound driver or null if no driver is bound.
driver() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device driver name.
driver() - Method in class org.onosproject.net.driver.DefaultDriverData
 
driver() - Method in class org.onosproject.net.driver.DefaultDriverHandler
 
driver() - Method in interface org.onosproject.net.driver.DriverData
Returns the parent device driver.
driver() - Method in interface org.onosproject.net.driver.DriverHandler
Returns the parent device driver.
driver(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the driver name.
Driver - Interface in org.onosproject.net.driver
Representation of a specific family of device drivers.
DRIVER - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the device driver name.
DRIVER_ENHANCED - org.onosproject.net.driver.DriverEvent.Type
Signifies that the driver configuration has changed in an additive manner.
DRIVER_READ - org.onosproject.security.AppPermission.Type
 
DRIVER_REDUCED - org.onosproject.net.driver.DriverEvent.Type
Signifies that the driver configuration has been reduced in some way.
DRIVER_WRITE - org.onosproject.security.AppPermission.Type
 
driverAdminService - Variable in class org.onosproject.net.driver.AbstractIndependentDriverLoader
 
DriverAdminService - Interface in org.onosproject.net.driver
Service for managing drivers and driver behaviour implementations.
DriverData - Interface in org.onosproject.net.driver
Container for data about an entity, e.g.
DriverEvent - Class in org.onosproject.net.driver
Driver configuration change event.
DriverEvent(DriverEvent.Type, Driver) - Constructor for class org.onosproject.net.driver.DriverEvent
Creates an event of a given type and for the specified driver and the current time.
DriverEvent(DriverEvent.Type, Driver, long) - Constructor for class org.onosproject.net.driver.DriverEvent
Creates an event of a given type and for the specified driver and time.
DriverEvent.Type - Enum in org.onosproject.net.driver
Type of driver events.
DriverHandler - Interface in org.onosproject.net.driver
Representation of context for interacting with a device.
DriverListener - Interface in org.onosproject.net.driver
Entity capable of receiving driver related events.
DriverNameCompleter - Class in org.onosproject.cli.net
Device driver name completer.
DriverNameCompleter() - Constructor for class org.onosproject.cli.net.DriverNameCompleter
 
DriverPrimordialResolver - Interface in org.onosproject.net.driver
Entity capable of resolving a driver using the primordial information of the manufacturer, hardware name/version and software version.
DriverProvider - Interface in org.onosproject.net.driver
Represents entity capable of providing device drivers and their behaviours.
DriverProvidersListCommand - Class in org.onosproject.cli.net
Lists device drivers.
DriverProvidersListCommand() - Constructor for class org.onosproject.cli.net.DriverProvidersListCommand
 
DriverRegistry - Interface in org.onosproject.net.driver
Service for obtaining drivers and driver behaviour implementations.
DriverResolver - Interface in org.onosproject.net.driver
Entity capable of resolving a driver using its name.
drivers - Variable in class org.onosproject.net.driver.DefaultDriverProvider
 
driverService - Variable in class org.onosproject.common.net.AbstractDeviceProvider
 
driverService() - Static method in class org.onosproject.net.AbstractProjectableModel
Returns the currently bound driver service reference.
DriverService - Interface in org.onosproject.net.driver
Service for obtaining drivers and driver behaviour implementations.
DriversListCommand - Class in org.onosproject.cli.net
Lists device drivers.
DriversListCommand() - Constructor for class org.onosproject.cli.net.DriversListCommand
 
drop() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
Add a NOACTION when DROP instruction is explicitly specified.
drop() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Adds a drop instruction.
drop() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Drops the incoming message.
drop(NeighbourMessageContext) - Method in interface org.onosproject.net.neighbour.NeighbourMessageActions
Drops the incoming message.
DROP - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Action
Drop action.
DROP - org.onosproject.net.meter.Band.Type
Simple rate limiter which drops packets when the rate is exceeded.
dropped() - Method in class org.onosproject.net.PipelineTraceableHitChain
Set the dropped flag.
dropped() - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
Sets dropped in the result.
DROPPED - org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Means packet is dropped by the pipeline.
droppedPackets() - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
droppedPackets() - Method in interface org.onosproject.net.packet.PacketInFilter
Get the count of the dropped packets for this filter type.
dropPrecedence() - Method in interface org.onosproject.net.meter.Band
Only meaningful in the case of a REMARK band type.
dropPrecedence() - Method in class org.onosproject.net.meter.DefaultBand
 
dropPrecedence(short) - Method in interface org.onosproject.net.meter.Band.Builder
Assigns the drop precedence for this band.
dropPrecedence(short) - Method in class org.onosproject.net.meter.DefaultBand.Builder
 
dropPrecedence(Short) - Method in class org.onosproject.net.behaviour.BandwidthProfileAction.Builder
Sets the drop precedence of this builder.
drops() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Returns true if this FAR drops packets, and false otherwise.
DSAKPS_GENERAL_MASK - Static variable in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
dscp() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
dscp() - Method in interface org.onosproject.net.behaviour.QueueDescription
Returns dscp in range 0 to 63.
dscp() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
dscp() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Dscp value, it meaning depends on the used marking.
dscp() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModDscpInstruction
 
dscp(Integer) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
 
dscp(Integer) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
Returns queue description builder with given dscp.
DSCP_CLASS - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Action
Marking sets DSCP class.
DSCP_PRECEDENCE - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Action
Marking increases DSCP drop precedence.
dscpClass(DscpClass) - Method in class org.onosproject.net.behaviour.BandwidthProfileAction.Builder
Sets the DSCP class of this builder.
DscpClass - Enum in org.onlab.packet
Represents the DiffServ classes defined by the IPv4/IPv6 DSCP value.
DSS_MESSAGE_HANDLER_THREAD_POOL_SIZE - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
DSS_MESSAGE_HANDLER_THREAD_POOL_SIZE_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
dst() - Method in class org.onlab.graph.AbstractEdge
 
dst() - Method in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
dst() - Method in class org.onlab.graph.DefaultMutablePath
 
dst() - Method in class org.onlab.graph.DefaultPath
 
dst() - Method in class org.onlab.graph.DisjointPathPair
 
dst() - Method in interface org.onlab.graph.Edge
Returns the edge destination vertex.
dst() - Method in interface org.onlab.graph.GraphPathSearch.Result
Returns the search destination, if was was given.
dst() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
Get the destination address of this unidirectional GTP tunnel.
dst() - Method in class org.onosproject.net.DefaultLink
 
dst() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
dst() - Method in class org.onosproject.net.link.DefaultLinkDescription
 
dst() - Method in interface org.onosproject.net.Link
Returns the link destination connection point.
dst() - Method in interface org.onosproject.net.link.LinkDescription
Returns the link destination.
dst() - Method in class org.onosproject.net.LinkKey
Returns destination connection point.
dst() - Method in class org.onosproject.net.topology.DefaultTopologyEdge
 
dst(ConnectPoint) - Method in class org.onosproject.net.DefaultLink.Builder
Sets the destination connect point to be used by the builder.
dst(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
Sets the destination for the intent that will be built.
dst(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
Sets the destination for the intent that will be built.
dst(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
Sets the destination for the intent that will be built.
dst(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
Sets the destination for the intent that will be built.
dstMac() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the destination MAC address of the message.
DTP_MAX_BATCH_MS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
DTP_MAX_BATCH_MS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
DTP_MAX_EVENTS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
DTP_MAX_EVENTS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
DTP_MAX_IDLE_MS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
DTP_MAX_IDLE_MS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
DUID_EN - org.onlab.packet.dhcp.Dhcp6Duid.DuidType
 
DUID_LL - org.onlab.packet.dhcp.Dhcp6Duid.DuidType
 
DUID_LLT - org.onlab.packet.dhcp.Dhcp6Duid.DuidType
 
DUID_UUID - org.onlab.packet.dhcp.Dhcp6Duid.DuidType
 
dummy() - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a dummy criterion.
DUMMY - org.onosproject.net.flow.criteria.Criterion.Type
An empty criterion.
dump() - Method in class org.onosproject.ui.lion.LionBundle
Dump the contents of the bundle.
dump(ChannelBuffer) - Static method in class org.onlab.util.HexDump
Deprecated.
Dump the buffer content in hex format.
dumpString() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns a detailed (multi-line) string showing the contents of the topology.
duplicate() - Method in class org.onlab.packet.ARP
Make an exact copy of the ARP packet.
duplicate() - Method in class org.onlab.packet.Ethernet
Make an exact copy of the ethernet packet.
DURABLE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for durable links.
duration() - Method in class org.onlab.util.Counter
Returns the duration expressed in fractional number of seconds.
DURATION - org.onosproject.net.flow.StatTriggerField
Time flow entry has been alive.
durationNano() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
durationNano() - Method in interface org.onosproject.net.device.PortStatistics
Returns the time port has been alive in nano seconds.
durationSec() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
durationSec() - Method in interface org.onosproject.net.device.PortStatistics
Returns the time port has been alive in seconds.
DWDM - org.onosproject.net.GridType
 

E

E_BAND_MAX - Static variable in class org.onlab.util.Spectrum
 
E_BAND_MIN - Static variable in class org.onlab.util.Spectrum
 
EAP - Class in org.onlab.packet
EAP (Extensible Authentication Protocol) packet.
EAP() - Constructor for class org.onlab.packet.EAP
Default EAP constructor that sets the EAP code to 0.
EAP(byte, byte, byte, byte[]) - Constructor for class org.onlab.packet.EAP
EAP constructor that initially sets all fields.
EAP_HDR_LEN_REQ_RESP - Static variable in class org.onlab.packet.EAP
 
EAP_HDR_LEN_SUC_FAIL - Static variable in class org.onlab.packet.EAP
 
EAPOL - Class in org.onlab.packet
EAPOL (Extensible Authentication Protocol over LAN) header.
EAPOL - org.onlab.packet.EthType.EtherType
 
EAPOL() - Constructor for class org.onlab.packet.EAPOL
 
EAPOL_ASF - Static variable in class org.onlab.packet.EAPOL
 
EAPOL_KEY - Static variable in class org.onlab.packet.EAPOL
 
EAPOL_LOGOFF - Static variable in class org.onlab.packet.EAPOL
 
EAPOL_MKA - Static variable in class org.onlab.packet.EAPOL
 
EAPOL_PACKET - Static variable in class org.onlab.packet.EAPOL
 
EAPOL_START - Static variable in class org.onlab.packet.EAPOL
 
EAPOLMkpdu - Class in org.onlab.packet
EAPOL MKA (EAPOL MAC Key Agreement Protocol) header.
EAPOLMkpdu() - Constructor for class org.onlab.packet.EAPOLMkpdu
 
EAPOLMkpduBasicParameterSet - Class in org.onlab.packet
Class representing EAPOL MKPDU Basic Parameter Set.
EAPOLMkpduBasicParameterSet() - Constructor for class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
EAPOLMkpduBasicParameterSet.SCI - Class in org.onlab.packet
MKA Secure Channel Identifier.
EAPOLMkpduDistributedSAKParameterSet - Class in org.onlab.packet
Class representing MKPDU MACSec SAK Use Parameter Set (GCM-AES 128).
EAPOLMkpduDistributedSAKParameterSet() - Constructor for class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
EAPOLMkpduDistributedSAKParameterSet.KeyWrapper - Interface in org.onlab.packet
 
EAPOLMkpduICVIndicatorParameterSet - Class in org.onlab.packet
Class representing MKPDU ICV Indicator.
EAPOLMkpduICVIndicatorParameterSet() - Constructor for class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
 
EAPOLMkpduMACSecUseParameterSet - Class in org.onlab.packet
Class representing MKPDU MACSec SAK Use Parameter Set.
EAPOLMkpduMACSecUseParameterSet() - Constructor for class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
EAPOLMkpduParameterSet - Interface in org.onlab.packet
Class representing EAPOL MKPDU Parameter Set.
EAPOLMkpduPeerListParameterSet - Class in org.onlab.packet
Class representing MKPDU Live/Potential Peer List Parameter Set.
EAPOLMkpduPeerListParameterSet() - Constructor for class org.onlab.packet.EAPOLMkpduPeerListParameterSet
 
EAPOLMkpduPeerListParameterSet.MemberDetails - Class in org.onlab.packet
 
EARTH_RADIUS_KM - Static variable in class org.onlab.util.GeoLocation
 
ebs() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the excess burst size (EBS) of this bandwidth profile.
ebs(Integer) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the excess burst size (EBS) of this builder.
EC_FLOW_RULE_STORE_PERSISTENCE_ENABLED - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
EC_FLOW_RULE_STORE_PERSISTENCE_ENABLED_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
ECE - org.onosproject.net.flow.criteria.Criterion.TcpFlags
ECN-Echo.
ECHO_REPLY - org.onosproject.cli.net.Icmp6Type
Echo Reply.
ECHO_REPLY - Static variable in class org.onlab.packet.ICMP6
Echo Reply.
ECHO_REQUEST - org.onosproject.cli.net.Icmp6Type
Echo Request.
ECHO_REQUEST - Static variable in class org.onlab.packet.ICMP6
Echo Request.
Edge<V extends Vertex> - Interface in org.onlab.graph
Representation of a graph edge.
EDGE - org.onosproject.net.Link.Type
Signifies that this link is an edge, i.e.
EDGE_PORT_ADDED - org.onosproject.net.edge.EdgePortEvent.Type
Signifies that a new edge port was detected.
EDGE_PORT_REMOVED - org.onosproject.net.edge.EdgePortEvent.Type
Signifies that a new edge port vanished.
EdgeLink - Interface in org.onosproject.net
Abstraction of a link between an end-station host and the network infrastructure.
edgeLinkCount() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the number of edge links configured in the topology.
edgeLinkId() - Method in class org.onosproject.ui.model.topo.UiHost
Returns the identifier for the edge link between this host and the device to which it is connected.
EdgePortEvent - Class in org.onosproject.net.edge
Describes an event pertaining to edge-port inventory.
EdgePortEvent(EdgePortEvent.Type, ConnectPoint) - Constructor for class org.onosproject.net.edge.EdgePortEvent
Creates a new edge port event.
EdgePortEvent(EdgePortEvent.Type, ConnectPoint, long) - Constructor for class org.onosproject.net.edge.EdgePortEvent
Creates a new edge port event.
EdgePortEvent.Type - Enum in org.onosproject.net.edge
 
EdgePortListener - Interface in org.onosproject.net.edge
Entity capable of receiving edge port events.
EdgePortService - Interface in org.onosproject.net.edge
Service for interacting with an inventory of network edge ports.
EdgePortsListCommand - Class in org.onosproject.cli.net
Lists all edge ports.
EdgePortsListCommand() - Constructor for class org.onosproject.cli.net.EdgePortsListCommand
 
edges - Variable in class org.onlab.graph.DepthFirstSearch.SpanningTreeResult
 
edges() - Method in class org.onlab.graph.DefaultMutablePath
 
edges() - Method in class org.onlab.graph.DefaultPath
 
edges() - Method in class org.onlab.graph.DepthFirstSearch.SpanningTreeResult
Returns the map of edge type.
edges() - Method in class org.onlab.graph.DisjointPathPair
 
edges() - Method in interface org.onlab.graph.Path
Returns the list of edges comprising the path.
edges() - Method in class org.onosproject.net.topology.DefaultGraphDescription
 
edges() - Method in interface org.onosproject.net.topology.GraphDescription
Returns the set of topology graph edges.
EdgeWeigher<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Abstraction of a graph edge weight function.
EF - org.onlab.packet.DscpClass
 
EGRESS - org.onosproject.net.Direction
 
EGRESS - org.onosproject.net.flowobjective.ForwardingObjective.Flag
An objective to program egress pipeline.
EGRESS_POLICER - org.onosproject.net.behaviour.QosDescription.Type
DPDK egress policer.
EGRESS_TIMESTAMP - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
The device local time when the INT packet was processed by the egress port.
EGRESS_TX_UTIL - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
Current utilization of the egress port via witch the INT packet was sent out.
egressInnerVlan() - Method in class org.onosproject.net.config.basics.McastConfig
Gets egress inner VLAN of multicast traffic.
egressPacket() - Method in class org.onosproject.net.PipelineTraceableHitChain
Returns the egress packet after traversing the pipeline.
egressPoint() - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
Returns the port on which the traffic should egress.
egressPoints() - Method in class org.onosproject.net.intent.LinkCollectionIntent
Returns the egress points of the intent.
egressPoints() - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
Returns the set of ports on which the traffic should egress.
egressPort() - Method in class org.onosproject.net.pi.runtime.PiPreReplica
Returns the egress port of this replica.
egressVlan() - Method in class org.onosproject.net.config.basics.McastConfig
Gets egress VLAN of multicast traffic.
ELAPSED_TIME - org.onlab.packet.DHCP6.OptionCode
 
ELECTION_TIMEOUT_MILLIS - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
ELECTION_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
electionTimeoutMillis() - Method in class org.onosproject.store.service.LeaderElectorOptions
Returns the election timeout in milliseconds.
element() - Method in class org.onlab.util.UnmodifiableDeque
 
element() - Method in class org.onosproject.net.DefaultPort
 
element() - Method in interface org.onosproject.net.Port
Returns the parent network element to which this port belongs.
element() - Method in class org.onosproject.net.utils.ForwardingPort
 
Element - Interface in org.onosproject.net
Base abstraction of a network element, i.e.
ELEMENT_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
ELEMENT_ID_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
elementA() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the identifier of the first element.
elementB() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the identifier of the second element.
elementId() - Method in class org.onosproject.net.ConnectPoint
Returns the network element identifier.
elementId() - Method in class org.onosproject.ui.topo.AbstractHighlight
Returns the element identifier.
ElementId - Class in org.onosproject.net
Immutable representation of a network element identity.
ElementId() - Constructor for class org.onosproject.net.ElementId
 
emit(OutboundPacket) - Method in interface org.onosproject.net.packet.PacketProgrammable
Emits the specified outbound packet onto the network from the device.
emit(OutboundPacket) - Method in interface org.onosproject.net.packet.PacketProvider
Emits the specified outbound packet onto the network.
emit(OutboundPacket) - Method in interface org.onosproject.net.packet.PacketService
Emits the specified outbound packet onto the network.
emit(OutboundPacket) - Method in interface org.onosproject.net.packet.PacketStore
Decides which instance should emit the packet and forwards the packet to that instance.
EMIT - org.onosproject.net.packet.PacketEvent.Type
Signifies that the packet should be emitted out a local port.
emitPacket(ByteBuffer, Optional<TrafficTreatment>) - Method in interface org.onosproject.net.edge.EdgePortService
Emits the specified packet, with optional treatment to all edge ports.
emitPacket(DeviceId, ByteBuffer, Optional<TrafficTreatment>) - Method in interface org.onosproject.net.edge.EdgePortService
Emits the specified packet, with optional treatment to all edge ports.
emitResponse(ConnectPoint, ByteBuffer) - Method in interface org.onosproject.net.proxyarp.ProxyArpStoreDelegate
Emits ARP or neighbour discovery response packet.
EMPTY - Static variable in class org.onosproject.net.DefaultAnnotations
 
EMPTY - Static variable in class org.onosproject.net.pi.runtime.PiMatchKey
 
EMPTY - Static variable in class org.onosproject.ui.table.cell.AbstractCellFormatter
 
emptyHitChain() - Static method in class org.onosproject.net.PipelineTraceableHitChain
Creates an empty pipeline hit chain.
emptyIsNotFound(Set<T>, String) - Static method in class org.onlab.util.Tools
Returns the specified set if the set is not null and not empty; otherwise throws a not found exception.
emptySelector() - Static method in class org.onosproject.net.flow.DefaultTrafficSelector
Returns an empty traffic selector.
emptyTreatment() - Static method in class org.onosproject.net.flow.DefaultTrafficTreatment
Returns an empty traffic treatment.
enable(PortNumber) - Method in interface org.onosproject.net.behaviour.PortAdmin
Enable administratively a port.
enabled() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
Returns the status of INT functionality.
enabled() - Method in class org.onosproject.net.config.basics.BasicFeatureConfig
Indicates whether the feature for the subject is enabled.
enabled(boolean) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns the status of INT.
enabled(Boolean) - Method in class org.onosproject.net.config.basics.BasicFeatureConfig
Specifies whether the feature for the subject is to be enabled.
enableLocalController() - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
Returns bridge description builder with local controller enabled.
enableLocalController() - Method in interface org.onosproject.net.behaviour.BridgeDescription
Returns whether to use local controller as an OpenFlow controller of the bridge if no controllers are specified.
enableLocalController() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
 
enableLocalController() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
 
enablePscEncap(int) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Instructs the UPF-programmable device to use GTP-U extension PDU Session Container (PSC) when doing encap of downlink packets, with the given QoS Flow Identifier (QFI).
enableVlan(Collection<VlanId>) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Enables VLANs on a device.
enableVlan(VlanId) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Enables a VLAN on a device.
ENC_GROUP_IPV4_BYTE_LENGTH - Static variable in class org.onlab.packet.pim.PIMAddrGroup
 
ENC_GROUP_IPV6_BYTE_LENGTH - Static variable in class org.onlab.packet.pim.PIMAddrGroup
 
ENC_SOURCE_IPV4_BYTE_LENGTH - Static variable in class org.onlab.packet.pim.PIMAddrSource
 
ENC_SOURCE_IPV6_BYTE_LENGTH - Static variable in class org.onlab.packet.pim.PIMAddrSource
 
ENC_UNICAST_IPV4_BYTE_LENGTH - Static variable in class org.onlab.packet.pim.PIMAddrUnicast
 
ENC_UNICAST_IPV6_BYTE_LENGTH - Static variable in class org.onlab.packet.pim.PIMAddrUnicast
 
encaps() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
True if this FAR encapsulates packets in a GTP tunnel, and false otherwise.
EncapSecurityPayload - Class in org.onlab.packet.ipv6
Implements IPv6 Encapsulating Security Payload (ESP) extension header format.
EncapSecurityPayload() - Constructor for class org.onlab.packet.ipv6.EncapSecurityPayload
 
encapsulateMessage(EAP) - Method in class org.onlab.packet.RADIUS
Encapsulates an EAP packet in this RADIUS packet.
EncapsulationConstraint - Class in org.onosproject.net.intent.constraint
Encapsulation to manage core transportation.
EncapsulationConstraint(EncapsulationType) - Constructor for class org.onosproject.net.intent.constraint.EncapsulationConstraint
Creates a new encapsulation constraint.
EncapsulationConstraint(EncapsulationType, Identifier<?>) - Constructor for class org.onosproject.net.intent.constraint.EncapsulationConstraint
Creates a new encapsulation constraint with suggested identifier.
EncapsulationType - Enum in org.onosproject.net
 
encapType() - Method in class org.onosproject.net.intent.constraint.EncapsulationConstraint
Returns the encapsulation type required by this constraint.
EncapTypeCompleter - Class in org.onosproject.cli.net
Encapsulation type completer.
EncapTypeCompleter() - Constructor for class org.onosproject.cli.net.EncapTypeCompleter
 
encode(Iterable<T>, CodecContext) - Method in class org.onosproject.codec.JsonCodec
Encodes the collection of the specified entities.
encode(Object) - Method in interface org.onosproject.store.serializers.StoreSerializer
Deprecated.
Serializes the specified object into bytes.
encode(Object, OutputStream) - Method in interface org.onosproject.store.serializers.StoreSerializer
Deprecated.
Serializes the specified object into bytes.
encode(Object, ByteBuffer) - Method in interface org.onosproject.store.serializers.StoreSerializer
Deprecated.
Serializes the specified object into bytes.
encode(ExtensionSelector, CodecContext) - Method in interface org.onosproject.net.flow.ExtensionSelectorCodec
Encodes an extension selector to an JSON object.
encode(ExtensionTreatment, CodecContext) - Method in interface org.onosproject.net.flow.ExtensionTreatmentCodec
Encodes an extension treatment to an JSON object.
encode(T) - Method in interface org.onosproject.net.resource.DiscreteResourceCodec
Encodes the specified object to an integer.
encode(T) - Method in interface org.onosproject.store.service.Serializer
Serialize the specified object.
encode(T, Class<T>) - Method in interface org.onosproject.codec.CodecContext
Encodes the specified entity into JSON using codec registered to this context.
encode(T, CodecContext) - Method in class org.onosproject.codec.JsonCodec
Encodes the specified entity into JSON.
encodeArray(Class<T>, String, Iterable<T>) - Method in class org.onosproject.rest.AbstractWebResource
Returns JSON object wrapping the array encoding of the specified collection of items.
endIndex() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
endIndex() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns the end index (inclusive) of the meters.
Endpoint - Class in org.onosproject.store.cluster.messaging
Representation of a TCP/UDP communication end point.
Endpoint(IpAddress, int) - Constructor for class org.onosproject.store.cluster.messaging.Endpoint
 
endPointA() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
 
endPointA() - Method in class org.onosproject.ui.model.topo.UiEdgeLink
 
endPointA() - Method in class org.onosproject.ui.model.topo.UiLink
Returns the identifier of end-point A in string form.
endPointA() - Method in class org.onosproject.ui.model.topo.UiRegionDeviceLink
 
endPointA() - Method in class org.onosproject.ui.model.topo.UiRegionLink
 
endPointB() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
 
endPointB() - Method in class org.onosproject.ui.model.topo.UiEdgeLink
 
endPointB() - Method in class org.onosproject.ui.model.topo.UiLink
Returns the identifier of end-point B in string form.
endPointB() - Method in class org.onosproject.ui.model.topo.UiRegionDeviceLink
 
endPointB() - Method in class org.onosproject.ui.model.topo.UiRegionLink
 
endPortA() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
 
endPortA() - Method in class org.onosproject.ui.model.topo.UiLink
Returns the port number (as a string) for end-point A, if applicable.
endPortB() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
 
endPortB() - Method in class org.onosproject.ui.model.topo.UiEdgeLink
 
endPortB() - Method in class org.onosproject.ui.model.topo.UiLink
Returns the port number (as a string) for end-point B, if applicable.
endPortB() - Method in class org.onosproject.ui.model.topo.UiRegionDeviceLink
 
ENDSTATION - Static variable in class org.onosproject.ui.GlyphConstants
 
EntityNotFoundMapper - Class in org.onlab.rest.exceptions
Mapper for service not found exceptions to the NOT_FOUND response code.
EntityNotFoundMapper() - Constructor for class org.onlab.rest.exceptions.EntityNotFoundMapper
 
entityType() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
 
entityType() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
 
entityType() - Method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
 
entityType() - Method in class org.onosproject.net.pi.runtime.PiHandle
Returns the type of entity identified by this handle.
entityType() - Method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
 
entityType() - Method in class org.onosproject.net.pi.runtime.PiPreEntryHandle
 
entityType() - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
 
entityType() - Method in class org.onosproject.net.pi.service.PiTranslatedEntity
Returns the type of the translated entity.
entries() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
entries() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns a collection of each key-value pair in this map.
entries() - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns a collection of each key-value pair in this map.
entry() - Method in class org.onosproject.store.service.SetEvent
Returns the entry this event concerns.
ENTRY_LEN - Static variable in class org.onlab.packet.RIPngEntry
 
ENTRY_LEN - Static variable in class org.onlab.packet.RIPV2Entry
 
entrySet() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
entrySet() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
entrySet() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
entrySet() - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns the set of entries contained in this map.
entrySet() - Method in interface org.onosproject.store.service.ConsistentMap
Returns the set of entries contained in this map.
entrySet() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Returns a set of mappings contained in this map.
EnumFormatter - Class in org.onosproject.ui.table.cell
Formats enum types to be readable strings.
enumFromString(String) - Static method in enum org.onosproject.net.behaviour.ControlProtocolVersion
Alternative method to valueOf.
enumFromString(String) - Static method in enum org.onosproject.net.EncapsulationType
Alternative method to valueOf.
enumString() - Method in class org.onosproject.net.pi.runtime.data.PiEnumString
Return protocol-independent enum string instance.
ENUMSTRING - org.onosproject.net.pi.model.PiData.Type
Enum String.
envelope(String, ObjectNode) - Static method in class org.onosproject.ui.JsonUtils
Composes a message structure for the given message type and payload.
EPERM - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
EQ_MASTER - Static variable in class org.onosproject.ui.GlyphConstants
 
equals(Object) - Method in class org.onlab.graph.AbstractEdge
 
equals(Object) - Method in class org.onlab.graph.AdjacencyListsGraph
 
equals(Object) - Method in class org.onlab.graph.DefaultMutablePath
 
equals(Object) - Method in class org.onlab.graph.DefaultPath
 
equals(Object) - Method in class org.onlab.graph.DisjointPathPair
 
equals(Object) - Method in class org.onlab.graph.Heap
 
equals(Object) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
equals(Object) - Method in class org.onlab.graph.ScalarWeight
 
equals(Object) - Method in class org.onlab.packet.ARP
 
equals(Object) - Method in class org.onlab.packet.BasePacket
 
equals(Object) - Method in class org.onlab.packet.bmp.Bmp
 
equals(Object) - Method in class org.onlab.packet.bmp.BmpPeer
 
equals(Object) - Method in class org.onlab.packet.ChassisId
 
equals(Object) - Method in class org.onlab.packet.Data
 
equals(Object) - Method in class org.onlab.packet.dhcp.CircuitId
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.Dhcp6Option
 
equals(Object) - Method in class org.onlab.packet.dhcp.DhcpOption
 
equals(Object) - Method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
 
equals(Object) - Method in class org.onlab.packet.EAP
 
equals(Object) - Method in class org.onlab.packet.EAPOL
 
equals(Object) - Method in class org.onlab.packet.Ethernet
 
equals(Object) - Method in class org.onlab.packet.EthType
 
equals(Object) - Method in class org.onlab.packet.ICMP
 
equals(Object) - Method in class org.onlab.packet.ICMP6
 
equals(Object) - Method in class org.onlab.packet.ICMPEcho
 
equals(Object) - Method in class org.onlab.packet.IGMP
 
equals(Object) - Method in class org.onlab.packet.IGMPMembership
 
equals(Object) - Method in class org.onlab.packet.IGMPQuery
 
equals(Object) - Method in class org.onlab.packet.IpAddress
 
equals(Object) - Method in class org.onlab.packet.IpPrefix
 
equals(Object) - Method in class org.onlab.packet.IPv4
 
equals(Object) - Method in class org.onlab.packet.ipv6.Authentication
 
equals(Object) - Method in class org.onlab.packet.ipv6.BaseOptions
 
equals(Object) - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
 
equals(Object) - Method in class org.onlab.packet.IPv6
 
equals(Object) - Method in class org.onlab.packet.ipv6.Fragment
 
equals(Object) - Method in class org.onlab.packet.ipv6.Routing
 
equals(Object) - Method in class org.onlab.packet.lacp.Lacp
 
equals(Object) - Method in class org.onlab.packet.lacp.LacpBaseTlv
 
equals(Object) - Method in class org.onlab.packet.lacp.LacpCollectorTlv
 
equals(Object) - Method in class org.onlab.packet.lacp.LacpState
 
equals(Object) - Method in class org.onlab.packet.LLDP
 
equals(Object) - Method in class org.onlab.packet.LLDPOrganizationalTLV
 
equals(Object) - Method in class org.onlab.packet.LLDPTLV
 
equals(Object) - Method in class org.onlab.packet.MacAddress
 
equals(Object) - Method in class org.onlab.packet.ndp.NeighborAdvertisement
 
equals(Object) - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
equals(Object) - Method in class org.onlab.packet.ndp.NeighborSolicitation
 
equals(Object) - Method in class org.onlab.packet.ndp.Redirect
 
equals(Object) - Method in class org.onlab.packet.ndp.RouterAdvertisement
 
equals(Object) - Method in class org.onlab.packet.ndp.RouterSolicitation
 
equals(Object) - Method in class org.onlab.packet.PIM
 
equals(Object) - Method in class org.onlab.packet.pim.PIMAddrGroup
 
equals(Object) - Method in class org.onlab.packet.pim.PIMAddrSource
 
equals(Object) - Method in class org.onlab.packet.pim.PIMAddrUnicast
 
equals(Object) - Method in class org.onlab.packet.RIP
 
equals(Object) - Method in class org.onlab.packet.RIPng
 
equals(Object) - Method in class org.onlab.packet.RIPngEntry
 
equals(Object) - Method in class org.onlab.packet.RIPV2AuthEntry
 
equals(Object) - Method in class org.onlab.packet.RIPV2Entry
 
equals(Object) - Method in class org.onlab.packet.Slow
 
equals(Object) - Method in class org.onlab.packet.TCP
 
equals(Object) - Method in class org.onlab.packet.TpPort
 
equals(Object) - Method in class org.onlab.packet.UDP
 
equals(Object) - Method in class org.onlab.packet.VXLAN
 
equals(Object) - Method in class org.onlab.util.ClosedOpenRange
 
equals(Object) - Method in class org.onlab.util.Counter
 
equals(Object) - Method in class org.onlab.util.Frequency
 
equals(Object) - Method in class org.onlab.util.Identifier
Compares two device key identifiers for equality.
equals(Object) - Method in class org.onlab.util.ImmutableByteSequence
 
equals(Object) - Method in class org.onlab.util.Match
 
equals(Object) - Method in class org.onlab.util.UnmodifiableDeque
 
equals(Object) - Method in class org.onosproject.alarm.DefaultAlarm
 
equals(Object) - Method in class org.onosproject.cfg.ConfigProperty
Equality is considered only on the basis of property name.
equals(Object) - Method in class org.onosproject.cluster.ClusterEvent
 
equals(Object) - Method in class org.onosproject.cluster.ClusterMetadata
 
equals(Object) - Method in class org.onosproject.cluster.ClusterMetadataEvent
 
equals(Object) - Method in class org.onosproject.cluster.DefaultControllerNode
 
equals(Object) - Method in class org.onosproject.cluster.DefaultPartition
 
equals(Object) - Method in class org.onosproject.cluster.Leader
 
equals(Object) - Method in class org.onosproject.cluster.Leadership
 
equals(Object) - Method in class org.onosproject.cluster.LeadershipEvent
 
equals(Object) - Method in class org.onosproject.cluster.Member
 
equals(Object) - Method in class org.onosproject.cluster.PartitionDiff
 
equals(Object) - Method in class org.onosproject.cluster.RoleInfo
 
equals(Object) - Method in class org.onosproject.core.DefaultApplication
 
equals(Object) - Method in class org.onosproject.core.DefaultApplicationId
 
equals(Object) - Method in class org.onosproject.core.Version
 
equals(Object) - Method in class org.onosproject.cpman.ControlLoadSnapshot
 
equals(Object) - Method in class org.onosproject.cpman.ControlMetricsRequest
 
equals(Object) - Method in class org.onosproject.cpman.ControlResourceRequest
 
equals(Object) - Method in class org.onosproject.cpman.DefaultControlMessage
 
equals(Object) - Method in class org.onosproject.cpman.MetricValue
 
equals(Object) - Method in class org.onosproject.event.Change
 
equals(Object) - Method in class org.onosproject.mastership.MastershipEvent
 
equals(Object) - Method in class org.onosproject.mastership.MastershipInfo
 
equals(Object) - Method in class org.onosproject.mastership.MastershipTerm
 
equals(Object) - Method in class org.onosproject.net.AbstractDescription
 
equals(Object) - Method in class org.onosproject.net.behaviour.BandwidthProfile
 
equals(Object) - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
 
equals(Object) - Method in class org.onosproject.net.behaviour.BridgeName
 
equals(Object) - Method in class org.onosproject.net.behaviour.ControllerInfo
 
equals(Object) - Method in class org.onosproject.net.behaviour.DefaultPatchDescription
 
equals(Object) - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
equals(Object) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
equals(Object) - Method in class org.onosproject.net.behaviour.DeviceCpuStats
 
equals(Object) - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
 
equals(Object) - Method in class org.onosproject.net.behaviour.DeviceSystemStats
 
equals(Object) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
 
equals(Object) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective
 
equals(Object) - Method in class org.onosproject.net.behaviour.MirroringName
 
equals(Object) - Method in class org.onosproject.net.behaviour.MirroringStatistics
 
equals(Object) - Method in class org.onosproject.net.behaviour.QosId
 
equals(Object) - Method in class org.onosproject.net.behaviour.QueueId
 
equals(Object) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
equals(Object) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
equals(Object) - Method in class org.onosproject.net.behaviour.trafficcontrol.PolicingResource
 
equals(Object) - Method in class org.onosproject.net.behaviour.TunnelEndPoint
 
equals(Object) - Method in class org.onosproject.net.behaviour.TunnelKey
 
equals(Object) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
 
equals(Object) - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
 
equals(Object) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
 
equals(Object) - Method in class org.onosproject.net.behaviour.upf.UpfInterface
 
equals(Object) - Method in class org.onosproject.net.ConnectPoint
 
equals(Object) - Method in class org.onosproject.net.DataPlaneEntity
 
equals(Object) - Method in class org.onosproject.net.DefaultAnnotations
 
equals(Object) - Method in class org.onosproject.net.DefaultDevice
 
equals(Object) - Method in class org.onosproject.net.DefaultDisjointPath
 
equals(Object) - Method in class org.onosproject.net.DefaultHost
 
equals(Object) - Method in class org.onosproject.net.DefaultLink
 
equals(Object) - Method in class org.onosproject.net.DefaultPath
 
equals(Object) - Method in class org.onosproject.net.DefaultPort
 
equals(Object) - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
equals(Object) - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
 
equals(Object) - Method in class org.onosproject.net.device.DefaultPortDescription
 
equals(Object) - Method in class org.onosproject.net.DeviceId
 
equals(Object) - Method in class org.onosproject.net.driver.DefaultDriver
 
equals(Object) - Method in class org.onosproject.net.FilteredConnectPoint
 
equals(Object) - Method in class org.onosproject.net.flow.BatchOperation
 
equals(Object) - Method in class org.onosproject.net.flow.BatchOperationEntry
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.ArpHaCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.ArpOpCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.ArpPaCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.EthCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.EthTypeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.ExtensionCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.ExtensionSelectorType
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IcmpCodeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IcmpTypeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.Icmpv6CodeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.Icmpv6TypeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPDscpCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPEcnCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPProtocolCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPv6ExthdrFlagsCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPv6FlowLabelCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPv6NDLinkLayerAddressCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.IPv6NDTargetAddressCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.LambdaCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.MetadataCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.MplsBosCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.MplsCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.MplsTcCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.OchSignalCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.OchSignalTypeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.OduSignalIdCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.OduSignalTypeCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.PbbIsidCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.PiCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.PortCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.SctpPortCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.TcpFlagsCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.TcpPortCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.TunnelIdCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.UdpPortCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.VlanIdCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.criteria.VlanPcpCriterion
 
equals(Object) - Method in class org.onosproject.net.flow.DefaultFlowRule
 
equals(Object) - Method in class org.onosproject.net.flow.DefaultTrafficSelector
 
equals(Object) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
equals(Object) - Method in interface org.onosproject.net.flow.FlowRule
Equality for flow rules only considers 'match equality'.
equals(Object) - Method in class org.onosproject.net.flow.instructions.ExtensionTreatmentType
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.ExtensionInstructionWrapper
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.GroupInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.MetadataInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.MeterInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.NoActionInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.OutputInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.SetQueueInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.TableTypeTransition
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.Instructions.TruncateInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction.ModOchSignalInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction.ModOduSignalIdInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModEtherInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsBosInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsHeaderInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsLabelInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsTtlInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModTunnelIdInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanHeaderInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanIdInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanPcpInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpEthInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpIPInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpOpInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModDscpInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPv6FlowLabelInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModTtlInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction.ModTransportPortInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.PiInstruction
 
equals(Object) - Method in class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
 
equals(Object) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
equals(Object) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
equals(Object) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
equals(Object) - Method in class org.onosproject.net.flowobjective.DefaultNextTreatment
 
equals(Object) - Method in class org.onosproject.net.flowobjective.FilteringObjQueueKey
 
equals(Object) - Method in class org.onosproject.net.flowobjective.ForwardingObjQueueKey
 
equals(Object) - Method in class org.onosproject.net.flowobjective.IdNextTreatment
 
equals(Object) - Method in class org.onosproject.net.flowobjective.NextObjQueueKey
 
equals(Object) - Method in class org.onosproject.net.group.DefaultGroup
 
equals(Object) - Method in class org.onosproject.net.group.DefaultGroupBucket
 
equals(Object) - Method in class org.onosproject.net.group.DefaultGroupDescription
 
equals(Object) - Method in class org.onosproject.net.group.DefaultGroupKey
 
equals(Object) - Method in class org.onosproject.net.group.GroupBuckets
 
equals(Object) - Method in class org.onosproject.net.group.GroupOperation
 
equals(Object) - Method in class org.onosproject.net.host.DefaultHostDescription
 
equals(Object) - Method in class org.onosproject.net.host.InterfaceIpAddress
 
equals(Object) - Method in class org.onosproject.net.HostId
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.BandwidthConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.EncapsulationConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.LatencyConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.LinkTypeConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.MarkerConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.MeteredConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.ObstacleConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.TierConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.constraint.WaypointConstraint
 
equals(Object) - Method in class org.onosproject.net.intent.Intent
 
equals(Object) - Method in class org.onosproject.net.intent.IntentData
 
equals(Object) - Method in class org.onosproject.net.intent.IntentOperation
 
equals(Object) - Method in class org.onosproject.net.intent.IntentOperationContext
 
equals(Object) - Method in class org.onosproject.net.intent.Key
 
equals(Object) - Method in class org.onosproject.net.intf.Interface
 
equals(Object) - Method in class org.onosproject.net.IpElementId
 
equals(Object) - Method in class org.onosproject.net.link.DefaultLinkDescription
 
equals(Object) - Method in class org.onosproject.net.LinkKey
 
equals(Object) - Method in class org.onosproject.net.MarkerResource
 
equals(Object) - Method in class org.onosproject.net.mcast.McastEvent
Deprecated.
 
equals(Object) - Method in class org.onosproject.net.mcast.McastRoute
Deprecated.
 
equals(Object) - Method in class org.onosproject.net.meter.DefaultMeter
 
equals(Object) - Method in class org.onosproject.net.meter.MeterFeaturesKey
Deprecated.
 
equals(Object) - Method in class org.onosproject.net.meter.MeterKey
 
equals(Object) - Method in class org.onosproject.net.meter.MeterOperation
 
equals(Object) - Method in class org.onosproject.net.meter.MeterTableKey
 
equals(Object) - Method in class org.onosproject.net.NshContextHeader
 
equals(Object) - Method in class org.onosproject.net.NshServiceIndex
 
equals(Object) - Method in class org.onosproject.net.OchSignal
 
equals(Object) - Method in class org.onosproject.net.OduSignalId
 
equals(Object) - Method in class org.onosproject.net.packet.DefaultInboundPacket
 
equals(Object) - Method in class org.onosproject.net.packet.DefaultOutboundPacket
 
equals(Object) - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
equals(Object) - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiBitString
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiBool
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiEnumString
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiErrorString
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiHeader
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiHeaderStack
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnionStack
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiStruct
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.data.PiTuple
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiAction
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionParam
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionSet
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiActionSet.WeightedAction
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiCounterCell
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiCounterCellData
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiExactFieldMatch
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiGroupKey
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiLpmFieldMatch
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMatchKey
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMeterBand
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiOptionalFieldMatch
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiPacketOperation
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiPreReplica
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiRangeFieldMatch
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiRegisterCellId
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiTableEntry
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
 
equals(Object) - Method in class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
 
equals(Object) - Method in class org.onosproject.net.PipelineTraceableHitChain
 
equals(Object) - Method in class org.onosproject.net.PipelineTraceablePacket
 
equals(Object) - Method in class org.onosproject.net.PortNumber
 
equals(Object) - Method in class org.onosproject.net.provider.ProviderId
 
equals(Object) - Method in class org.onosproject.net.region.DefaultRegion
 
equals(Object) - Method in class org.onosproject.net.resource.ContinuousResource
 
equals(Object) - Method in class org.onosproject.net.resource.ContinuousResourceId
 
equals(Object) - Method in class org.onosproject.net.resource.DiscreteResource
 
equals(Object) - Method in class org.onosproject.net.resource.DiscreteResourceId
 
equals(Object) - Method in class org.onosproject.net.resource.ResourceAllocation
 
equals(Object) - Method in class org.onosproject.net.resource.ResourceConsumerId
 
equals(Object) - Method in class org.onosproject.net.ResourceGroup
 
equals(Object) - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
equals(Object) - Method in class org.onosproject.net.topology.DefaultTopologyEdge
 
equals(Object) - Method in class org.onosproject.net.topology.DefaultTopologyVertex
 
equals(Object) - Method in class org.onosproject.net.TributarySlot
 
equals(Object) - Method in class org.onosproject.net.utils.ForwardingPort
 
equals(Object) - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
 
equals(Object) - Method in class org.onosproject.routing.NextHop
 
equals(Object) - Method in class org.onosproject.routing.NextHopGroupKey
 
equals(Object) - Method in class org.onosproject.security.Permission
 
equals(Object) - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
 
equals(Object) - Method in class org.onosproject.store.cluster.messaging.Endpoint
 
equals(Object) - Method in class org.onosproject.store.cluster.messaging.MessageSubject
 
equals(Object) - Method in class org.onosproject.store.flow.ReplicaInfo
 
equals(Object) - Method in class org.onosproject.store.LogicalTimestamp
 
equals(Object) - Method in class org.onosproject.store.primitives.MapUpdate
 
equals(Object) - Method in class org.onosproject.store.primitives.NodeUpdate
 
equals(Object) - Method in class org.onosproject.store.primitives.PartitionEvent
 
equals(Object) - Method in class org.onosproject.store.service.AtomicValueEvent
 
equals(Object) - Method in class org.onosproject.store.service.DocumentPath
 
equals(Object) - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
 
equals(Object) - Method in class org.onosproject.store.service.MapEvent
 
equals(Object) - Method in class org.onosproject.store.service.MultimapEvent
 
equals(Object) - Method in class org.onosproject.store.service.MultiValuedTimestamp
 
equals(Object) - Method in class org.onosproject.store.service.SetEvent
 
equals(Object) - Method in class org.onosproject.store.service.TransactionLog
 
equals(Object) - Method in class org.onosproject.store.service.Version
 
equals(Object) - Method in class org.onosproject.store.service.Versioned
 
equals(Object) - Method in class org.onosproject.store.service.WallClockTimestamp
 
equals(Object) - Method in interface org.onosproject.store.Timestamp
 
equals(Object) - Method in class org.onosproject.ui.lion.LionBundle.LionItem
 
equals(Object) - Method in class org.onosproject.ui.model.topo.UiLinkId
 
equals(Object) - Method in class org.onosproject.ui.topo.Mod
 
equals(Object) - Method in class org.onosproject.ui.topo.PropertyPanel.Prop
 
equals(Object) - Method in class org.onosproject.ui.UiSessionToken
 
equals(Object) - Method in class org.onosproject.ui.UiView
 
equals(Object) - Method in class org.onosproject.upgrade.UpgradeEvent
 
ERR_MSG - Static variable in interface org.onosproject.net.meter.Band
 
errCode() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
errCode() - Method in interface org.onosproject.net.flow.FlowEntry
Indicates the error code.
error - Variable in class org.onlab.rest.exceptions.AbstractMapper
Holds the current exception for use in subclasses.
error(String) - Method in class org.onlab.junit.LoggerAdapter
 
error(String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
error(String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
error(String, Object...) - Method in class org.onosproject.cli.AbstractShellCommand
Prints the arguments using the specified format to error stream.
error(String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
error(String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
error(Marker, String) - Method in class org.onlab.junit.LoggerAdapter
 
error(Marker, String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
error(Marker, String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
error(Marker, String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
error(Marker, String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
ERROR - org.onlab.util.Tools.LogLevel
 
ERROR - org.onosproject.ui.topo.NodeBadge.Status
 
errorContexts() - Method in class org.onosproject.net.intent.IntentInstallationContext
Retrieves the error contexts.
errorCount() - Method in class org.onosproject.net.intent.IntentData
Returns the number of times that this intent has encountered an error during installation or withdrawal.
errorString() - Method in class org.onosproject.net.pi.runtime.data.PiErrorString
Return protocol-independent error string instance.
ERRORSTRING - org.onosproject.net.pi.model.PiData.Type
Error String.
errType() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
errType() - Method in interface org.onosproject.net.flow.FlowEntry
Indicates the error type.
ESP - org.onosproject.cli.net.ExtHeader
Encapsulated Security Payload.
ESP - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Encrypted Sec Payload header present.
ETH_DST - org.onosproject.net.flow.criteria.Criterion.Type
Ethernet destination address.
ETH_DST - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
Ether dst modification.
ETH_DST_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
Ethernet destination address with masking.
ETH_SRC - org.onosproject.net.flow.criteria.Criterion.Type
Ethernet source address.
ETH_SRC - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
Ether src modification.
ETH_SRC_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
Ethernet source address with masking.
ETH_TYPE - org.onosproject.net.flow.criteria.Criterion.Type
Ethernet frame type.
EthCriterion - Class in org.onosproject.net.flow.criteria
Implementation of MAC address criterion.
Ethernet - Class in org.onlab.packet
Ethernet Packet.
Ethernet() - Constructor for class org.onlab.packet.Ethernet
By default, set Ethernet to untagged.
ETHERNET_HEADER_LENGTH - Static variable in class org.onlab.packet.Ethernet
 
ethernetType() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsHeaderInstruction
 
ethernetType() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanHeaderInstruction
 
etherType - Variable in class org.onlab.packet.Ethernet
 
ethType - Variable in class org.onlab.packet.LLDP
 
ethType() - Method in enum org.onlab.packet.EthType.EtherType
 
ethType() - Method in class org.onosproject.net.flow.criteria.EthTypeCriterion
Gets the Ethernet frame type to match.
EthType - Class in org.onlab.packet
Representation of an Ethertype.
EthType - Enum in org.onosproject.cli.net
Allowed values for Ethernet types.
EthType(int) - Constructor for class org.onlab.packet.EthType
Builds the EthType.
EthType(short) - Constructor for class org.onlab.packet.EthType
Builds the EthType.
EthType.EtherType - Enum in org.onlab.packet
A list of known ethertypes.
EthTypeCompleter - Class in org.onosproject.cli.net
Ethernet type completer.
EthTypeCompleter() - Constructor for class org.onosproject.cli.net.EthTypeCompleter
 
EthTypeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of Ethernet type criterion (16 bits unsigned integer).
event(E) - Method in interface org.onosproject.event.EventListener
Reacts to the specified event.
event(IntentEvent) - Method in class org.onosproject.cli.net.IntentCycleCommand
 
event(IntentEvent) - Method in class org.onosproject.cli.net.IntentPushTestCommand
 
event(AtomicValueEvent<V>) - Method in interface org.onosproject.store.service.AtomicValueEventListener
Reacts to the specified event.
event(DocumentTreeEvent<V>) - Method in interface org.onosproject.store.service.DocumentTreeListener
Callback notifying about change to document tree node.
event(EventuallyConsistentMapEvent<K, V>) - Method in interface org.onosproject.store.service.EventuallyConsistentMapListener
Reacts to the specified event.
event(MapEvent<K, V>) - Method in interface org.onosproject.store.service.MapEventListener
Reacts to the specified event.
event(MultimapEvent<K, V>) - Method in interface org.onosproject.store.service.MultimapEventListener
Reacts to the specified event.
event(SetEvent<E>) - Method in interface org.onosproject.store.service.SetEventListener
Reacts to the specified event.
Event<T extends Enum,​S> - Interface in org.onosproject.event
Abstraction of an of a time-stamped event pertaining to an arbitrary subject.
EVENT_READ - org.onosproject.security.AppPermission.Type
 
EVENT_WRITE - org.onosproject.security.AppPermission.Type
 
EventDeliveryService - Interface in org.onosproject.event
Abstraction of an entity capable of accepting events to be posted and then dispatching them to the appropriate event sink.
eventDispatcher - Variable in class org.onosproject.event.AbstractListenerManager
 
eventDispatcher - Variable in class org.onosproject.net.provider.AbstractListenerProviderRegistry
 
EventDispatcher - Interface in org.onosproject.event
Abstraction of a mechanism capable of accepting and dispatching events to appropriate event sinks.
EventFilter<E extends Event> - Interface in org.onosproject.event
Entity capable of filtering events.
EventListener<E extends Event> - Interface in org.onosproject.event
Entity capable of receiving events.
EventMetric - Class in org.onlab.metrics
Metric measurements for events.
EventMetric(MetricsService, String, String) - Constructor for class org.onlab.metrics.EventMetric
Constructor.
eventRateMeter() - Method in class org.onlab.metrics.EventMetric
Gets the event rate meter.
eventReceived() - Method in class org.onlab.metrics.EventMetric
Updates the metric measurements for a single event.
EventSink<E extends Event> - Interface in org.onosproject.event
Abstraction of an event sink capable of processing the specified event types.
EventSinkRegistry - Interface in org.onosproject.event
Abstraction of an event sink registry capable of tracking sinks based on their event class.
eventType() - Method in class org.onosproject.ui.RequestHandler
Returns the event type that this handler handles.
eventType(ObjectNode) - Static method in class org.onosproject.ui.JsonUtils
Returns the event type from the specified event.
EVENTUALLY_CONSISTENT_MAP - org.onosproject.store.service.DistributedPrimitive.Type
Map with eventual consistency semantics.
EventuallyConsistentMap<K,​V> - Interface in org.onosproject.store.service
A distributed, eventually consistent map.
eventuallyConsistentMapBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new EventuallyConsistentMapBuilder.
eventuallyConsistentMapBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new EventuallyConsistentMapBuilder.
EventuallyConsistentMapBuilder<K,​V> - Interface in org.onosproject.store.service
Builder for eventually consistent maps.
EventuallyConsistentMapEvent<K,​V> - Class in org.onosproject.store.service
Representation of a EventuallyConsistentMap update notification.
EventuallyConsistentMapEvent(String, EventuallyConsistentMapEvent.Type, K, V) - Constructor for class org.onosproject.store.service.EventuallyConsistentMapEvent
Creates a new event object.
EventuallyConsistentMapEvent.Type - Enum in org.onosproject.store.service
 
EventuallyConsistentMapListener<K,​V> - Interface in org.onosproject.store.service
Listener to be notified about updates to a EventuallyConsistentMap.
evict(NodeId) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
evict(NodeId) - Method in interface org.onosproject.store.service.AsyncLeaderElector
Attempts to evict a node from all leadership elections it is registered for.
evict(NodeId) - Method in interface org.onosproject.store.service.LeaderElector
Attempts to evict a node from all leadership elections it is registered for.
EVICTION - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
EXACT - org.onosproject.net.pi.model.PiMatchType
Exact match type.
EXACT_MASK - Static variable in class org.onlab.packet.MacAddress
Mask that indicates exact match on the MacAddress.
exactlyEquals(PortNumber) - Method in class org.onosproject.net.PortNumber
Indicates whether some other PortNumber object is equal to this one including it's name.
exactMatch(FlowRule) - Method in class org.onosproject.net.flow.DefaultFlowRule
 
exactMatch(FlowRule) - Method in interface org.onosproject.net.flow.FlowRule
Returns whether this flow rule is an exact match to the flow rule given in the argument.
exceptionalFuture(Throwable) - Static method in class org.onlab.util.Tools
Returns a future that is completed exceptionally.
ExceptionTest - Class in org.onlab.junit
Base for exception tests.
ExceptionTest() - Constructor for class org.onlab.junit.ExceptionTest
 
EXCESS - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Type
Excess rate.
execute() - Method in class org.onosproject.cli.AbstractShellCommand
 
execute(Runnable) - Method in class org.onlab.junit.NullScheduledExecutor
 
execute(Runnable) - Method in class org.onlab.util.BoundedThreadPool
 
execute(Runnable) - Method in class org.onlab.util.OrderedExecutor
 
execute(Runnable) - Method in class org.onlab.util.PredictableExecutor
 
execute(Runnable) - Method in class org.onlab.util.SharedScheduledExecutorService
 
execute(Runnable, int) - Method in class org.onlab.util.PredictableExecutor
Executes given command at some time in the future.
execute(Runnable, Function<Runnable, Integer>) - Method in class org.onlab.util.PredictableExecutor
Executes given command at some time in the future.
execute(Collection<IntentData>) - Method in interface org.onosproject.net.intent.IntentBatchDelegate
Submits the specified batch of intent operations for processing.
executeBatch(FlowRuleBatchOperation) - Method in interface org.onosproject.net.flow.FlowRuleProvider
Installs a batch of flow rules.
EXISTING_METER - org.onosproject.net.meter.MeterFailReason
A meter with the same identifier already exists.
existingRequests() - Method in interface org.onosproject.net.packet.PacketStore
Obtains all existing requests in the system.
EXPECTED - Static variable in class org.onosproject.net.link.DefaultLinkDescription
 
EXPERIMENTAL - org.onosproject.net.meter.Band.Type
Defines an experimental meter band.
EXT_MATCH_FLOW_TYPE - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
ExtendedSet<E> - Class in org.onlab.util
A Set providing additional get, insertOrReplace and conditionalRemove methods.
ExtendedSet(Map<E, E>) - Constructor for class org.onlab.util.ExtendedSet
Constructs a new instance by backing it with the supplied Map.
extension(ExtensionSelector, DeviceId) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates an extension criterion for the specified extension selector.
extension(ExtensionSelector, DeviceId) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
extension(ExtensionSelector, DeviceId) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Uses an extension selector.
extension(ExtensionTreatment, DeviceId) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
extension(ExtensionTreatment, DeviceId) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates an extension instruction.
extension(ExtensionTreatment, DeviceId) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Uses an extension treatment.
extension(PiPipeconf.ExtensionType) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
 
extension(PiPipeconf.ExtensionType) - Method in interface org.onosproject.net.pi.model.PiPipeconf
Returns, if present, an input stream pointing at the beginning of a file representing a device-specific or control protocol-specific extension of this configuration.
Extension - Interface in org.onosproject.net.flow
An extension to the northbound APIs.
EXTENSION - org.onosproject.net.flow.criteria.Criterion.Type
Extension criterion.
EXTENSION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that an extension instruction will be used.
ExtensionCriterion - Class in org.onosproject.net.flow.criteria
Criterion for implementing selector extensions.
ExtensionCriterion(ExtensionSelector, DeviceId) - Constructor for class org.onosproject.net.flow.criteria.ExtensionCriterion
Constructor.
ExtensionCriterionSerializer - Class in org.onosproject.store.serializers
Serializer for extension criteria.
ExtensionCriterionSerializer() - Constructor for class org.onosproject.store.serializers.ExtensionCriterionSerializer
Constructs a extension criterion serializer.
extensionInstruction() - Method in class org.onosproject.net.flow.instructions.Instructions.ExtensionInstructionWrapper
 
ExtensionInstructionSerializer - Class in org.onosproject.store.serializers
Serializer for extension instructions.
ExtensionInstructionSerializer() - Constructor for class org.onosproject.store.serializers.ExtensionInstructionSerializer
Constructs a extension instruction serializer.
ExtensionPropertyException - Exception in org.onosproject.net.flow.instructions
Exception indicating there was an error while setting/getting an extension instruction property.
ExtensionPropertyException(String) - Constructor for exception org.onosproject.net.flow.instructions.ExtensionPropertyException
 
ExtensionPropertyException(String, Throwable) - Constructor for exception org.onosproject.net.flow.instructions.ExtensionPropertyException
 
extensionSelector() - Method in class org.onosproject.net.flow.criteria.ExtensionCriterion
Returns the extension selector.
ExtensionSelector - Interface in org.onosproject.net.flow.criteria
An extension for the selector API.
ExtensionSelectorCodec - Interface in org.onosproject.net.flow
Interface for encode and decode extension selector.
ExtensionSelectorResolver - Interface in org.onosproject.net.behaviour
Provides access to the extension selectors implemented by this driver.
ExtensionSelectorType - Class in org.onosproject.net.flow.criteria
Type of selector extensions.
ExtensionSelectorType(int) - Constructor for class org.onosproject.net.flow.criteria.ExtensionSelectorType
Creates an extension type with the given int type code.
ExtensionSelectorType.ExtensionSelectorTypes - Enum in org.onosproject.net.flow.criteria
A list of well-known named extension selector type codes.
ExtensionTreatment - Interface in org.onosproject.net.flow.instructions
An extension for the treatment API.
ExtensionTreatmentCodec - Interface in org.onosproject.net.flow
Interface for encode and decode extension treatment.
ExtensionTreatmentResolver - Interface in org.onosproject.net.behaviour
Provides access to the extension treatments implemented by this driver.
ExtensionTreatmentType - Class in org.onosproject.net.flow.instructions
Type of treatment extensions.
ExtensionTreatmentType(int) - Constructor for class org.onosproject.net.flow.instructions.ExtensionTreatmentType
Creates an extension type with the given int type code.
ExtensionTreatmentType.ExtensionTreatmentTypes - Enum in org.onosproject.net.flow.instructions
A list of well-known named extension instruction type codes.
exthdrFlags() - Method in class org.onosproject.net.flow.criteria.IPv6ExthdrFlagsCriterion
Gets the IPv6 Extension Header pseudo-field flags to match.
ExtHeader - Enum in org.onosproject.cli.net
Known values for IPv6 extension header field that can be supplied to the CLI.
ExtHeaderCompleter - Class in org.onosproject.cli.net
IPv6 extension header completer.
ExtHeaderCompleter() - Constructor for class org.onosproject.cli.net.ExtHeaderCompleter
 
extractExtreme() - Method in class org.onlab.graph.Heap
Extracts and returns the most extreme item from the heap.
extreme() - Method in class org.onlab.graph.Heap
Returns the most extreme item in the heap.

F

fail(MeterFailReason) - Static method in class org.onosproject.net.meter.MeterStoreResult
A failed store operation.
FAIL - org.onosproject.net.meter.MeterStoreResult.Type
 
FAIL_POLICY - org.onosproject.cli.net.Icmp6Code
Source address failed ingress/egress policy.
FAIL_POLICY - Static variable in class org.onlab.packet.ICMP6
Source address failed ingress/egress policy.
FAILED - org.onosproject.net.flow.FlowEntry.FlowEntryState
Indicates that the installation of this flow has failed.
FAILED - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent has failed compilation and that it cannot be satisfied by the network at this time.
FAILED - org.onosproject.net.intent.IntentState
Signifies that the intent has failed to be installed and cannot be satisfied given current network conditions.
failedIds() - Method in class org.onosproject.net.flow.CompletedBatchOperation
 
failedItems() - Method in interface org.onosproject.net.flow.BatchOperationResult
Obtains a set of items which failed.
failedItems() - Method in class org.onosproject.net.flow.CompletedBatchOperation
 
failedMeter(MeterOperation, MeterFailReason) - Method in interface org.onosproject.net.meter.MeterStore
Update the store by deleting the failed meter.
failedRetryCount() - Method in class org.onosproject.net.group.DefaultGroup
 
failedRetryCount() - Method in interface org.onosproject.net.group.Group
Returns the count for the number of attempts at programming a failed group.
failMode() - Method in interface org.onosproject.net.behaviour.BridgeDescription
Returns fail mode of the bridge.
failMode() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
 
failMode(BridgeDescription.FailMode) - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
Returns bridge description builder with a given fail mode.
failMode(BridgeDescription.FailMode) - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
 
FAILOVER - org.onosproject.net.flowobjective.NextObjective.Type
Failover handling.
FAILOVER - org.onosproject.net.group.GroupDescription.Type
Uses the first live bucket in a group.
FAILOVER - org.onosproject.net.intent.PathIntent.ProtectionType
Intent whose flow rule serves as the fast failover between primary and backup paths.
FAILURE - org.onosproject.net.behaviour.SoftwareUpgrade.Status
Indicates an aborted upgrade.
FAILURE - org.onosproject.store.service.CommitStatus
Indicates a aborted transaction i.e.
FAILURE - Static variable in class org.onlab.packet.EAP
 
failureCode() - Method in class org.onosproject.net.group.GroupOperation
Returns the failure code representing the failure of a group operation.
farId() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Get the PFCP session-local ID of the FAR that should apply to packets that match this PDR.
farId() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Get the PFCP session-local ID of the far that should apply to packets that this PDR matches.
farTableSize() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Return the number of maximum number of table entries the FAR table supports.
features() - Method in interface org.onosproject.app.ApplicationDescription
Returns the list of features comprising the application.
features() - Method in class org.onosproject.app.DefaultApplicationDescription
 
features() - Method in interface org.onosproject.core.Application
Returns the list of features comprising the application.
features() - Method in class org.onosproject.core.DefaultApplication
 
features() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
features() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns features flags that supported for meter actions by device.
featuresRepo() - Method in interface org.onosproject.app.ApplicationDescription
Returns the feature repository URI.
featuresRepo() - Method in class org.onosproject.app.DefaultApplicationDescription
 
featuresRepo() - Method in interface org.onosproject.core.Application
Returns the feature repository URI.
featuresRepo() - Method in class org.onosproject.core.DefaultApplication
 
fetchSinks(McastRoute) - Method in interface org.onosproject.net.mcast.MulticastRouteService
Deprecated.
Find the list of sinks for this route.
fetchSource(McastRoute) - Method in interface org.onosproject.net.mcast.MulticastRouteService
Deprecated.
Find the data source association for this multicast route.
FIBER - org.onosproject.net.Port.Type
Signifies optical fiber-based connectivity.
FIBER_SWITCH - org.onosproject.net.Device.Type
 
FIBER_SWITCH - Static variable in class org.onosproject.ui.GlyphConstants
 
field() - Method in exception org.onosproject.net.config.InvalidFieldException
Returns the field name.
FIELD_ALGAG_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
FIELD_MI_LENGTH - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
FIELD_MN_LENGTH - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
FIELD_SCI_LENGTH - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
fieldId() - Method in class org.onosproject.net.pi.runtime.PiFieldMatch
Returns the identifier of the field to be matched.
fieldMatch(PiMatchFieldId) - Method in class org.onosproject.net.flow.criteria.PiCriterion
If present, returns the field match associated with the given header field identifier.
fieldMatch(PiMatchFieldId) - Method in class org.onosproject.net.pi.runtime.PiMatchKey
If present, returns the field match associated with the given header field identifier.
fieldMatches() - Method in class org.onosproject.net.flow.criteria.PiCriterion
Returns all protocol-independent field matches defined by this criterion.
fieldMatches() - Method in class org.onosproject.net.pi.runtime.PiMatchKey
Returns the collection of field matches of this match key.
filePath() - Method in class org.onosproject.ui.UiTopoMap
Returns the filePath for this map.
FilePathValidator - Class in org.onlab.util
Utilities for validation of Zip files.
filter(Object) - Method in class org.onlab.util.StringFilter
Filters data according to a set of restrictions and a specific strategy.
filter(ContainerRequestContext) - Method in class org.onlab.rest.AuthorizationFilter
 
filter(DeviceId, FilteringObjective) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Installs the filtering rules onto the specified device.
filter(FilteringObjective) - Method in interface org.onosproject.net.behaviour.Pipeliner
Installs the filtering rules onto the device.
FILTER_DISABLED - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that this filter is disabled.
FILTER_INVALID - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that the filter applied is invalid filter.
FILTER_VALID - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that filter applied is a valid filter.
FilteredConnectPoint - Class in org.onosproject.net
Connection point with TrafficSelector field.
FilteredConnectPoint(ConnectPoint) - Constructor for class org.onosproject.net.FilteredConnectPoint
Creates filtered connect point with default traffic selector.
FilteredConnectPoint(ConnectPoint, TrafficSelector) - Constructor for class org.onosproject.net.FilteredConnectPoint
Creates new filtered connection point.
FilteredConnectPointSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for FilteredConnectPointSerializer.
FilteredConnectPointSerializer() - Constructor for class org.onosproject.store.serializers.FilteredConnectPointSerializer
Creates FilteredConnectPointSerializer serializer instance.
filteredEgressPoint() - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
Returns the port on which the traffic should egress.
filteredEgressPoint() - Method in class org.onosproject.net.intent.PointToPointIntent
Return the filtered port on which the traffic should exit.
filteredEgressPoint(FilteredConnectPoint) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
Sets the filtered egress point of the domain point to point intent that will be built.
filteredEgressPoint(FilteredConnectPoint) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
Sets the filtered egress point of the multi point to single point intent that will be built.
filteredEgressPoint(FilteredConnectPoint) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
Sets the filtered egress point of the point to point intent that will be built.
filteredEgressPoints() - Method in class org.onosproject.net.domain.DomainIntent
Returns the filtered connected points on which the traffic should egress.
filteredEgressPoints() - Method in class org.onosproject.net.intent.LinkCollectionIntent
Returns the egress points of the intent.
filteredEgressPoints() - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
Returns the set of filtered ports on which the traffic should egress.
filteredEgressPoints(Set<FilteredConnectPoint>) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
Sets the filtered egress points of the single point to multi point intent that will be built.
filteredEgressPoints(Set<FilteredConnectPoint>) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
Sets the filtered egress points of the single point to multi point intent that will be built.
filteredIngressPoint() - Method in class org.onosproject.net.intent.PointToPointIntent
Returns the filtered port on which the ingress traffic should be connected to the egress.
filteredIngressPoint() - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
Returns the filtered port on which the ingress traffic should be connected to the egress.
filteredIngressPoint(FilteredConnectPoint) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
Sets the filtered ingress point of the domain point to point intent that will be built.
filteredIngressPoint(FilteredConnectPoint) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
Sets the filtered ingress point of the point to point intent that will be built.
filteredIngressPoint(FilteredConnectPoint) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
Sets the filtered ingress point of the single point to multi point intent that will be built.
filteredIngressPoints() - Method in class org.onosproject.net.domain.DomainIntent
Returns the filtered connected points on which the ingress traffic should be connected to the egress.
filteredIngressPoints() - Method in class org.onosproject.net.intent.LinkCollectionIntent
Returns the filtered ingress points of the intent.
filteredIngressPoints() - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
Returns the set of ports on which ingress traffic should be connected to the egress port.
filteredIngressPoints(Set<FilteredConnectPoint>) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
Sets the filtered ingress point of the single point to multi point intent that will be built.
filteredIngressPoints(Set<FilteredConnectPoint>) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
Sets the filtered ingress point of the single point to multi point intent that will be built.
FilteringObjective - Interface in org.onosproject.net.flowobjective
Represents a filtering flow objective.
FilteringObjective.Builder - Interface in org.onosproject.net.flowobjective
Builder of Filtering objective entities.
FilteringObjective.Type - Enum in org.onosproject.net.flowobjective
 
FilteringObjQueueKey - Class in org.onosproject.net.flowobjective
Filtering objective queue key.
FilteringObjQueueKey(DeviceId, int, Criterion) - Constructor for class org.onosproject.net.flowobjective.FilteringObjQueueKey
 
FILTERS - Static variable in class org.onosproject.ui.GlyphConstants
 
FIN - org.onosproject.net.flow.criteria.Criterion.TcpFlags
No more data from sender.
findAvailablePort(int) - Static method in class org.onlab.junit.TestTools
 
findClusterMember(NodeId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the cluster member with the given identifier, or null if no such member exists.
findDevice(DeviceId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the device with the specified identifier, or null if no such device exists.
findDeviceLink(UiLinkId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the device link with the specified identifier, or null if no such link exists.
findEdgeLink(UiLinkId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the edge link with the specified identifier, or null if no such link exists.
findHost(HostId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the host with the specified identifier, or null if no such host exists.
findRegion(RegionId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the region with the specified identifier, or null if no such region exists.
findSynthLinks(RegionId) - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the synthetic links associated with the specified region.
fingerprint() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
Returns fingerprint to identify this protected transport entity.
fingerprint() - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
Returns fingerprint to identify this protected transport entity.
fingerprint() - Method in class org.onosproject.net.intent.IntentId
Returns the backing value.
fingerprint() - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
 
fingerprint() - Method in interface org.onosproject.net.pi.model.PiPipeconf
Returns the fingerprint of pipeconf.
fingerprint() - Method in class org.onosproject.net.ResourceGroup
Returns the backing value.
fingerprint(String) - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
Sets the fingerprint to identify this protected transport entity.
FINGERPRINT - Static variable in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Annotation key for virtual Port.
fingerprintMac(ClusterMetadata) - Static method in interface org.onosproject.net.link.ProbedLinkProvider
Build a stringified MAC address using the ClusterMetadata hash for uniqueness.
FIREWALL - org.onosproject.net.Device.Type
 
firstEntry() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
firstEntry() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the entry associated with the lowest key in the map.
firstEntry() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the lowest key in the map.
firstKey() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
firstKey() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the lowest key in the map.
firstKey() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the lowest key in the map.
firstOf(List<CompletableFuture<T>>) - Static method in class org.onlab.util.Tools
Returns a new CompletableFuture completed with the first result from a list of futures.
firstOf(List<CompletableFuture<T>>, Match<T>, T) - Static method in class org.onlab.util.Tools
Returns a new CompletableFuture completed by with the first positive result from a list of input CompletableFutures.
fit(int) - Method in class org.onlab.util.ImmutableByteSequence
Trims or expands a copy of this byte sequence so to fit the given bit-width.
FIXED_GRID - org.onosproject.net.OchSignalType
Represents fixed grid.
FIXED_GRID_SLOT_GRANULARITIES - Static variable in class org.onosproject.net.OchSignal
 
FIXED_HEADER_LENGTH - Static variable in class org.onlab.packet.ipv6.Authentication
 
FIXED_HEADER_LENGTH - Static variable in class org.onlab.packet.ipv6.BaseOptions
 
FIXED_HEADER_LENGTH - Static variable in class org.onlab.packet.IPv6
 
FIXED_HEADER_LENGTH - Static variable in class org.onlab.packet.ipv6.Routing
 
FIXED_OPTIONS_LENGTH - Static variable in class org.onlab.packet.ipv6.BaseOptions
 
FIXED_ROUTING_DATA_LENGTH - Static variable in class org.onlab.packet.ipv6.Routing
 
flag() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
flag() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective
Obtain the type of this objective.
flags - Variable in class org.onlab.packet.bmp.BmpPeer
 
flags - Variable in class org.onlab.packet.DHCP
 
flags - Variable in class org.onlab.packet.IPv4
 
flags - Variable in class org.onlab.packet.TCP
 
flags - Variable in class org.onlab.packet.VXLAN
 
flags() - Method in class org.onosproject.net.flow.criteria.TcpFlagsCriterion
Gets the TCP flags to match.
flapping() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link flapping in terms of percentage.
flapping(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link flapping.
FLAPPING - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for flapping.
FLAPPING - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
FLASH - org.onlab.packet.IPPrecedence
 
FLASH_OVERRIDE - org.onlab.packet.IPPrecedence
 
flavor() - Method in class org.onosproject.ui.topo.LinkHighlight
Returns the highlight flavor.
FLEX - org.onosproject.net.GridType
 
FLEX_GRID - org.onosproject.net.OchSignalType
Represents flex grid.
FLOAT - org.onosproject.cfg.ConfigProperty.Type
Indicates the value is a float.
FLOATING_ID - Static variable in class org.onlab.util.KryoNamespace
ID to use if this KryoNamespace does not define registration id.
flood() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Floods the incoming message out all ports except the input port.
flood(NeighbourMessageContext) - Method in interface org.onosproject.net.neighbour.NeighbourMessageActions
Floods the incoming message to all edge ports except the in port.
FLOOD - org.onosproject.net.PortNumber.Logical
 
FLOOD - Static variable in class org.onosproject.net.PortNumber
 
FLOOR - org.onosproject.net.region.Region.Type
Region represents a building floor.
floorDivision(long) - Method in class org.onlab.util.Frequency
Returns a Frequency whose value is Math.floorDiv(this, value).
floorEntry(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
floorEntry(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Returns the entry associated with the greatest key less than or equal to key.
floorEntry(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the greatest key less than or equal to key.
floorKey(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
floorKey(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the highest key less than or equal to key.
floorKey(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the highest key less than or equal to key.
flow() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a flow service implementation.
FLOW_COUNT - org.onosproject.net.flow.StatTriggerField
Number of aggregated flow entries.
FLOW_MOD_PACKET - org.onosproject.cpman.ControlMessage.Type
 
FLOW_MOD_PACKET - org.onosproject.cpman.ControlMetricType
 
FLOW_OP_TOPIC - Static variable in interface org.onosproject.net.flow.FlowRuleService
The topic used for obtaining globally unique ids.
FLOW_REMOVED_PACKET - org.onosproject.cpman.ControlMessage.Type
 
FLOW_REMOVED_PACKET - org.onosproject.cpman.ControlMetricType
 
FLOW_RULE_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
FLOW_TABLE - Static variable in class org.onosproject.ui.GlyphConstants
 
FlowEntry - Interface in org.onosproject.net.flow
Represents a generalized match & action pair to be applied to an infrastructure device.
FLOWENTRY_WITHLOAD_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
FlowEntry.FlowEntryState - Enum in org.onosproject.net.flow
 
FlowEntry.FlowLiveType - Enum in org.onosproject.net.flow
 
FlowEntryWithLoad - Class in org.onosproject.net.statistic
Load of flow entry with flow live type.
FlowEntryWithLoad(ConnectPoint, FlowEntry) - Constructor for class org.onosproject.net.statistic.FlowEntryWithLoad
Creates a new flow entry with load.
FlowEntryWithLoad(ConnectPoint, FlowEntry, Load) - Constructor for class org.onosproject.net.statistic.FlowEntryWithLoad
Creates a new flow entry with load.
FlowId - Class in org.onosproject.net.flow
Representation of a Flow ID.
FLOWINSTALLATIONFAILED - org.onosproject.net.flowobjective.ObjectiveError
The flow installation for this objective failed.
flowLabel - Variable in class org.onlab.packet.IPv6
 
flowLabel() - Method in class org.onosproject.net.flow.criteria.IPv6FlowLabelCriterion
Gets the IPv6 flow label to match.
flowLabel() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPv6FlowLabelInstruction
Gets the IPv6 flow label to set in the treatment.
flowLiveType() - Method in class org.onosproject.net.flow.DefaultTypedFlowEntry
 
flowLiveType() - Method in interface org.onosproject.net.flow.TypedStoredFlowEntry
Gets the flow live type for this entry.
FlowObjectiveCompositionCommand - Class in org.onosproject.cli.net
Manages FlowObjectiveComposition policy.
FlowObjectiveCompositionCommand() - Constructor for class org.onosproject.cli.net.FlowObjectiveCompositionCommand
 
FlowObjectiveIntent - Class in org.onosproject.net.intent
Intent expressed as (and backed by) a collection of flow objectives through which the intent is to be accomplished.
FlowObjectiveIntent() - Constructor for class org.onosproject.net.intent.FlowObjectiveIntent
Constructor for serialization.
FlowObjectiveIntent(ApplicationId, Key, List<DeviceId>, List<Objective>, Collection<NetworkResource>, ResourceGroup) - Constructor for class org.onosproject.net.intent.FlowObjectiveIntent
Creates a flow objective intent with the specified objectives and resources.
FlowObjectiveNextListCommand - Class in org.onosproject.cli.net
Returns a mapping of FlowObjective next-ids to the groups that get created by a device driver.
FlowObjectiveNextListCommand() - Constructor for class org.onosproject.cli.net.FlowObjectiveNextListCommand
 
FlowObjectivePendingNextCommand - Class in org.onosproject.cli.net
Returns a list of FlowObjective next-ids waiting to get created by device-drivers.
FlowObjectivePendingNextCommand() - Constructor for class org.onosproject.cli.net.FlowObjectivePendingNextCommand
 
FlowObjectiveQueueClearCommand - Class in org.onosproject.cli.net
Clear flow objective that are waiting for the completion of previous objective with the same key.
FlowObjectiveQueueClearCommand() - Constructor for class org.onosproject.cli.net.FlowObjectiveQueueClearCommand
 
FlowObjectiveQueueListCommand - Class in org.onosproject.cli.net
Displays flow objective that are waiting for the completion of previous objective with the same key.
FlowObjectiveQueueListCommand() - Constructor for class org.onosproject.cli.net.FlowObjectiveQueueListCommand
 
FlowObjectiveService - Interface in org.onosproject.net.flowobjective
Service for programming data plane flow rules in manner independent of specific device table pipeline configuration.
FlowObjectiveStore - Interface in org.onosproject.net.flowobjective
The flow objective store.
FlowObjectiveStoreDelegate - Interface in org.onosproject.net.flowobjective
Flow Objective store delegate abstraction.
flowRemoved(FlowEntry) - Method in interface org.onosproject.net.flow.FlowRuleProviderService
Signals that a flow rule that was previously installed has been removed.
FlowRule - Interface in org.onosproject.net.flow
Represents a generalized match & action pair to be applied to an infrastructure device.
FLOWRULE - org.onosproject.net.DataPlaneEntity.Type
Flow rule entity.
FLOWRULE_EVENT - org.onosproject.security.AppPermission.Type
 
FLOWRULE_READ - org.onosproject.security.AppPermission.Type
 
FLOWRULE_WRITE - org.onosproject.security.AppPermission.Type
 
FlowRule.Builder - Interface in org.onosproject.net.flow
A flowrule builder.
FlowRule.FlowRemoveReason - Enum in org.onosproject.net.flow
Reason for flow parameter received from switches.
FlowRuleBatchEntry - Class in org.onosproject.net.flow.oldbatch
Deprecated.
FlowRuleBatchEntry(FlowRuleBatchEntry.FlowRuleOperation, FlowRule) - Constructor for class org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry
Deprecated.
 
FlowRuleBatchEntry(FlowRuleBatchEntry.FlowRuleOperation, FlowRule, Long) - Constructor for class org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry
Deprecated.
 
FlowRuleBatchEntry.FlowRuleOperation - Enum in org.onosproject.net.flow.oldbatch
Deprecated.
 
FlowRuleBatchEvent - Class in org.onosproject.net.flow.oldbatch
Deprecated.
FlowRuleBatchEvent.Type - Enum in org.onosproject.net.flow.oldbatch
Deprecated.
Type of flow rule events.
FlowRuleBatchOperation - Class in org.onosproject.net.flow.oldbatch
Deprecated.
FlowRuleBatchOperation(Collection<FlowRuleBatchEntry>, DeviceId, long) - Constructor for class org.onosproject.net.flow.oldbatch.FlowRuleBatchOperation
Deprecated.
 
FlowRuleBatchRequest - Class in org.onosproject.net.flow.oldbatch
Deprecated.
FlowRuleBatchRequest(long, Set<FlowRuleBatchEntry>) - Constructor for class org.onosproject.net.flow.oldbatch.FlowRuleBatchRequest
Deprecated.
 
FlowRuleEvent - Class in org.onosproject.net.flow
Describes flow rule event.
FlowRuleEvent(FlowRuleEvent.Type, FlowRule) - Constructor for class org.onosproject.net.flow.FlowRuleEvent
Creates an event of a given type and for the specified flow rule and the current time.
FlowRuleEvent(FlowRuleEvent.Type, FlowRule, long) - Constructor for class org.onosproject.net.flow.FlowRuleEvent
Creates an event of a given type and for the specified flow rule and time.
FlowRuleEvent.Type - Enum in org.onosproject.net.flow
Type of flow rule events.
FlowRuleIntent - Class in org.onosproject.net.intent
An intent that enables to tell flow level operation.
FlowRuleIntent() - Constructor for class org.onosproject.net.intent.FlowRuleIntent
Constructor for serializer.
FlowRuleIntent(ApplicationId, Key, Collection<FlowRule>, Collection<NetworkResource>, PathIntent.ProtectionType, ResourceGroup) - Constructor for class org.onosproject.net.intent.FlowRuleIntent
Creates a flow rule intent with the specified key, flow rules to be set, and required network resources.
FlowRuleIntent(FlowRuleIntent, PathIntent.ProtectionType) - Constructor for class org.onosproject.net.intent.FlowRuleIntent
Creates a flow rule intent with all the same characteristics as the given one except for the flow rule type.
FlowRuleListener - Interface in org.onosproject.net.flow
Entity capable of receiving flow rule related events.
FlowRuleOperation - Class in org.onosproject.net.flow
Representation of an operation on a flow rule table.
FlowRuleOperation(FlowRule, FlowRuleOperation.Type) - Constructor for class org.onosproject.net.flow.FlowRuleOperation
 
FlowRuleOperation.Type - Enum in org.onosproject.net.flow
Type of flow table operations.
FlowRuleOperations - Class in org.onosproject.net.flow
A batch of flow rule operations that are broken into stages.
FlowRuleOperations() - Constructor for class org.onosproject.net.flow.FlowRuleOperations
 
FlowRuleOperations.Builder - Class in org.onosproject.net.flow
A builder for constructing flow rule operations.
FlowRuleOperationsContext - Interface in org.onosproject.net.flow
The context of a flow rule operations that will become the subject of the notification.
FlowRuleProgrammable - Interface in org.onosproject.net.flow
Flow rule programmable device behaviour.
FlowRuleProvider - Interface in org.onosproject.net.flow
Abstraction of a flow rule provider.
FlowRuleProviderRegistry - Interface in org.onosproject.net.flow
Abstraction for a flow rule provider registry.
FlowRuleProviderService - Interface in org.onosproject.net.flow
Service through which flow rule providers can inject information into the core.
flowRules() - Method in class org.onosproject.net.intent.FlowRuleIntent
Returns a collection of flow rules to be set.
FlowRuleService - Interface in org.onosproject.net.flow
Service for injecting flow rules into the environment and for obtaining information about flow rules already in the environment.
FlowRuleStatusCompleter - Class in org.onosproject.cli.net
Flow rule status completer.
FlowRuleStatusCompleter() - Constructor for class org.onosproject.cli.net.FlowRuleStatusCompleter
 
FlowRuleStore - Interface in org.onosproject.net.flow
Manages inventory of flow rules; not intended for direct use.
FlowRuleStoreDelegate - Interface in org.onosproject.net.flow
Flow rule store delegate abstraction.
FlowRuleStoreException - Exception in org.onosproject.net.flow
Top level exception for FlowRuleStore failures.
FlowRuleStoreException() - Constructor for exception org.onosproject.net.flow.FlowRuleStoreException
 
FlowRuleStoreException(String) - Constructor for exception org.onosproject.net.flow.FlowRuleStoreException
 
FlowRuleStoreException(Throwable) - Constructor for exception org.onosproject.net.flow.FlowRuleStoreException
 
FlowRuleStoreException.Interrupted - Exception in org.onosproject.net.flow
Flowrule store operation interrupted.
FlowRuleStoreException.Timeout - Exception in org.onosproject.net.flow
Flowrule store operation timeout.
flowRuleTranslator() - Method in interface org.onosproject.net.pi.service.PiTranslationService
Returns a flow rule translator.
flows() - Method in class org.onosproject.net.PipelineTraceableInput
Getter for the flows.
FLOWS - Static variable in class org.onosproject.ui.GlyphConstants
 
FLOWS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
FlowsListCommand - Class in org.onosproject.cli.net
Lists all currently-known flows.
FlowsListCommand() - Constructor for class org.onosproject.cli.net.FlowsListCommand
 
FlowStatisticService - Interface in org.onosproject.net.statistic
Service for obtaining individual flow statistic information about device and link in the system.
FlowStatisticStore - Interface in org.onosproject.net.statistic
Flow Store to house the computed statistics.
flowTunnelEndpoint() - Static method in class org.onosproject.net.behaviour.TunnelEndPoints
Returns a tunnel endpoint with FLOW keyword.
flowTunnelKey() - Static method in class org.onosproject.net.behaviour.TunnelKeys
Returns a tunnel key with FLOW keyword.
FOM_ACCUMULATOR_MAX_BATCH_MILLIS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_ACCUMULATOR_MAX_BATCH_MILLIS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_ACCUMULATOR_MAX_IDLE_MILLIS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_ACCUMULATOR_MAX_IDLE_MILLIS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_ACCUMULATOR_MAX_OBJECTIVES - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_ACCUMULATOR_MAX_OBJECTIVES_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_NUM_THREADS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
FOM_NUM_THREADS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
forActionProfile(PiActionProfileId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember.Builder
Sets the action profile identifier of this member.
ForbiddenMapper - Class in org.onlab.rest.exceptions
Mapper for service not found exceptions to the NOT_FOUND response code.
ForbiddenMapper() - Constructor for class org.onlab.rest.exceptions.ForbiddenMapper
 
forDevice(DeviceId) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
forDevice(DeviceId) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the deviceId for this flow rule.
forDevice(DeviceId) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
forDevice(DeviceId) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
forDevice(DeviceId) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
forDevice(DeviceId) - Method in interface org.onosproject.net.meter.Meter.Builder
Assigns the target device for this meter.
forDevice(DeviceId) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the target device for this meter features.
forDevice(DeviceId) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Assigns the target device for this meter.
forDeviceId(DeviceId) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
forDeviceId(DeviceId) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns the device for this policer.
forEach(BiConsumer<? super K, ? super V>) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
forEach(Consumer<? super E>) - Method in class org.onlab.util.UnmodifiableDeque
 
forget(PiHandle) - Method in interface org.onosproject.net.pi.service.PiTranslator
Removes any mapping for the given PI entity handle.
FORGOT - org.onosproject.net.pi.service.PiTranslationEvent.Type
Signals that a previously learned mapping between a PD entity and its PI counterpart has been removed.
format(Object) - Method in class org.onosproject.ui.table.cell.AbstractCellFormatter
 
format(Object) - Method in interface org.onosproject.ui.table.CellFormatter
Formats the specified value into a string appropriate for displaying in a table cell.
format(String, Object...) - Static method in class org.onlab.util.PositionalParameterStringFormatter
Formats a string using slf4j style positional parameter replacement.
FORMAT_LONG - Static variable in class org.onosproject.core.Version
 
FORMAT_MINIMAL - Static variable in class org.onosproject.core.Version
 
FORMAT_SHORT - Static variable in class org.onosproject.core.Version
 
formatBytes(long) - Static method in class org.onosproject.ui.topo.TopoUtils
Returns a value representing a count of bytes.
formatClippedBitRate(long) - Static method in class org.onosproject.ui.topo.TopoUtils
Returns a value representing a count of bits per second, (clipped to a maximum of 100 Gbps).
formatFlows(long) - Static method in class org.onosproject.ui.topo.TopoUtils
Returns human readable flow count, to be displayed as a label.
formatPacketRate(long) - Static method in class org.onosproject.ui.topo.TopoUtils
Returns a value representing a count of packets per second.
formatter() - Method in class org.onosproject.ui.topo.PropertyPanel
Returns a number formatter to use for formatting integer and long property values.
forSource(AlarmEntityId) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm source.
forTable(int) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
forTable(int) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the table id for this flow rule, when the identifier is of type TableId.Type.INDEX.
forTable(TableId) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
forTable(TableId) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the table identifier for this flow rule.
forTable(PiTableId) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the table identifier for this entry.
forTypes(Class<?>...) - Static method in interface org.onosproject.store.service.Serializer
 
forward(ConnectPoint) - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Forwards the message to a given output port.
forward(DeviceId, ForwardingObjective) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Installs the forwarding rules onto the specified device.
forward(ForwardingObjective) - Method in interface org.onosproject.net.behaviour.Pipeliner
Installs the forwarding rules onto the device.
forward(Interface) - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Forwards the message to a given interface.
forward(NeighbourMessageContext, ConnectPoint) - Method in interface org.onosproject.net.neighbour.NeighbourMessageActions
Forwards the incoming message to the given connect point.
forward(NeighbourMessageContext, Interface) - Method in interface org.onosproject.net.neighbour.NeighbourMessageActions
Forwards the incoming message to a given interface.
FORWARD_EDGE - org.onlab.graph.DepthFirstSearch.EdgeType
 
ForwardingActionRule - Class in org.onosproject.net.behaviour.upf
A single Forwarding Action Rule (FAR), an entity described in the 3GPP specifications (although that does not mean that this class is 3GPP compliant).
ForwardingActionRule.Builder - Class in org.onosproject.net.behaviour.upf
 
ForwardingDevice - Interface in org.onosproject.net.utils
A Device which forwards all its method calls to another Device.
ForwardingDeviceService - Class in org.onosproject.net.utils
A DeviceService which forwards all its method calls to another DeviceService.
ForwardingDeviceService(DeviceService) - Constructor for class org.onosproject.net.utils.ForwardingDeviceService
 
ForwardingObjective - Interface in org.onosproject.net.flowobjective
Represents a description of which types of traffic need to be forwarded through the device.
ForwardingObjective.Builder - Interface in org.onosproject.net.flowobjective
A forwarding objective builder.
ForwardingObjective.Flag - Enum in org.onosproject.net.flowobjective
Represents whether this objective is monolithic or may be broken down into parts.
ForwardingObjQueueKey - Class in org.onosproject.net.flowobjective
Forwarding objective queue key.
ForwardingObjQueueKey(DeviceId, int, TrafficSelector) - Constructor for class org.onosproject.net.flowobjective.ForwardingObjQueueKey
 
ForwardingPort - Class in org.onosproject.net.utils
A Port which forwards all its method calls to another Port.
ForwardingPort(Port) - Constructor for class org.onosproject.net.utils.ForwardingPort
 
forwards() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
True if this FAR does not drop packets.
FQ_CODEL - org.onosproject.net.behaviour.QosDescription.Type
Corresponds to Fair Queuing with Controlled Delay classifier.
FRAG - org.onosproject.cli.net.ExtHeader
Fragment header.
FRAG - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Fragment header present.
Fragment - Class in org.onlab.packet.ipv6
Implements IPv6 fragment extension header format.
Fragment() - Constructor for class org.onlab.packet.ipv6.Fragment
 
fragmentOffset - Variable in class org.onlab.packet.IPv4
 
fragmentOffset - Variable in class org.onlab.packet.ipv6.Fragment
 
freeMeterId(DeviceId, MeterId) - Method in interface org.onosproject.net.meter.MeterService
Deprecated.
in onos-2.5
freeMeterId(DeviceId, MeterId) - Method in interface org.onosproject.net.meter.MeterStore
Deprecated.
in onos-2.5, freeing an ID is closely related to removal of a meter so, this function is no longer exposed on interface
freePolicerId(PolicerId) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerConfigurable
Free a policer id.
freeze() - Method in class org.onlab.util.Counter
Freezes the counter in the current state including the counts and times.
frequency() - Method in enum org.onosproject.net.ChannelSpacing
 
Frequency - Class in org.onlab.util
Class representing frequency.
from(int) - Static method in class org.onosproject.cluster.PartitionId
Creates a partition identifier from an integer.
from(String) - Static method in class org.onosproject.store.primitives.TransactionId
Creates a new transaction identifier.
from(String) - Static method in class org.onosproject.store.service.DocumentPath
Creates a new DocumentPath from a period delimited path string.
from(String...) - Static method in class org.onosproject.store.service.DocumentPath
Creates a new DocumentPath from a list of path elements.
from(List<String>) - Static method in class org.onosproject.store.service.DocumentPath
Creates a new DocumentPath from a list of path elements.
from(List<String>, String) - Static method in class org.onosproject.store.service.DocumentPath
Creates a new DocumentPath from a list of path elements.
from(List<String>, String...) - Static method in class org.onosproject.store.service.DocumentPath
Creates a new DocumentPath from a list of path elements.
from(RoutersConfig.Router) - Static method in class org.onosproject.routing.RouterInfo
Creates a router info from a router config.
fromApp(ApplicationId) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
fromApp(ApplicationId) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns the application that built this policer.
fromApp(ApplicationId) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
fromApp(ApplicationId) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Assigns the application that built this flow rule to this object.
fromApp(ApplicationId) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
fromApp(ApplicationId) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
fromApp(ApplicationId) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
fromApp(ApplicationId) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Assigns an application id.
fromApp(ApplicationId) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Assigns an application id.
fromApp(ApplicationId) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Specifies the application which applied the filter.
fromApp(ApplicationId) - Method in interface org.onosproject.net.flowobjective.Objective.Builder
Specifies the application which applied the filter.
fromApp(ApplicationId) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
fromApp(ApplicationId) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
fromApp(ApplicationId) - Method in interface org.onosproject.net.meter.Meter.Builder
Assigns the application that built this meter.
fromApp(ApplicationId) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Assigns the application that built this meter.
fromBytes(byte[]) - Static method in class org.onosproject.store.cluster.messaging.ClusterMessage
Decodes a new ClusterMessage from raw bytes.
fromCompactListString(String) - Static method in class org.onosproject.ui.topo.LayoutLocation
Returns a list of layout locations from a compact string representation.
fromCompactString(String) - Static method in class org.onosproject.ui.topo.LayoutLocation
Produces a layout location instance from a compact string representation.
fromHex(String) - Static method in class org.onlab.util.Tools
Converts a string from hex to long.
fromHexString(String) - Static method in class org.onlab.util.HexString
Convert a colon-separated hex string to byte array.
fromHexString(String, String) - Static method in class org.onlab.util.HexString
Convert a hex-string with arbitrary separator to byte array.
fromInt(int) - Static method in class org.onosproject.core.Version
Returns an version from integer.
fromIPv4Address(int) - Static method in class org.onlab.packet.IPv4
Accepts an IPv4 address and returns of string of the form xxx.xxx.xxx.xxx, e.g., 192.168.0.1.
fromIPv4AddressCollection(Collection<Integer>) - Static method in class org.onlab.packet.IPv4
Accepts a collection of IPv4 addresses as integers and returns a single String useful in toString method's containing collections of IP addresses.
fromMeter(Meter) - Static method in class org.onosproject.net.behaviour.BandwidthProfile
Creates a bandwidth profile based on the parameters of a Meter.
fromShort(short) - Static method in enum org.onlab.packet.DscpClass
Returns the DSCP class Enum corresponding to the specified short.
fromShort(short) - Static method in enum org.onlab.packet.IPPrecedence
Returns the IP precedence Enum corresponding to the specified short.
fromString(String) - Static method in class org.onosproject.net.ConnectPoint
Parse a device connect point from a string.
fromString(String) - Static method in class org.onosproject.net.PortNumber
Returns PortNumber instance from String representation.
fromThisUpf(FlowRule) - Method in interface org.onosproject.net.behaviour.upf.UpfProgrammable
Checks if the given flow rule has been generated by this UPF behaviour.
futureGetOrElse(Future<T>, long, TimeUnit, T) - Static method in class org.onlab.util.Tools
Returns the future value when complete or if future completes exceptionally returns the defaultValue.
futureGetOrElse(Future<T>, T) - Static method in class org.onlab.util.Tools
Returns the future value when complete or if future completes exceptionally returns the defaultValue.

G

gaddr - Variable in class org.onlab.packet.IGMPGroup
 
GARBAGE - Static variable in class org.onosproject.ui.GlyphConstants
 
GARBAGE_COLLECT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
GARBAGE_COLLECT_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
GARBAGE_COLLECT_THRESH - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
GARBAGE_COLLECT_THRESH_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
gatewayIPAddress - Variable in class org.onlab.packet.DHCP
 
gbps(double) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in Gbps.
gbps(long) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in Gbps.
gBps(double) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in GBps.
gBps(long) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in GBps.
GBPS - org.onlab.util.DataRateUnit
Gigabit per second.
generateAnnotObjectNode(ChartModel) - Static method in class org.onosproject.ui.chart.ChartUtils
Generates a JSON object node from the annotations of the given chart model.
generateAnnotObjectNode(TableModel) - Static method in class org.onosproject.ui.table.TableUtils
Generates a JSON object node from the annotations of the given table model.
generateAuthCode() - Method in class org.onlab.packet.RADIUS
Generates an authenticator code.
generateDataPointArrayNode(ChartModel) - Static method in class org.onosproject.ui.chart.ChartUtils
Generates a JSON array node from the data points of the given chart model.
generateRowArrayNode(TableModel) - Static method in class org.onosproject.ui.table.TableUtils
Generates a JSON array node from the rows of the given table model.
Generator<T> - Class in org.onlab.util
Generator class that yields instances of T type objects as soon as they are ready.
Generator() - Constructor for class org.onlab.util.Generator
 
GENEVE - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a L3 tunnel.
GENID_LENGTH - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
GEO - org.onosproject.ui.topo.LayoutLocation.Type
 
geoCoordsSet() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns true if the geographical coordinates (latitude and longitude) are set on this element; false otherwise.
GeoDistanceLinkWeight - Class in org.onosproject.net.topology
Link weight for measuring link cost using the geo distance between link vertices as determined by the element longitude/latitude annotation.
GeoDistanceLinkWeight(DeviceService) - Constructor for class org.onosproject.net.topology.GeoDistanceLinkWeight
Creates a new link-weight with access to the specified device service.
GeoLocation - Class in org.onlab.util
Geo location specified in terms of longitude and latitude.
GeoLocation(double, double) - Constructor for class org.onlab.util.GeoLocation
Creates a new location using the specified coordinates.
geomap() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the identifier for the background geo-map.
geomap() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the symbolic name for the geomap for this layout.
geomap(String) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the name of the geomap (topojson file) to use for this layout.
geomap(String) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the name of the geomap for this layout.
geoMaps() - Method in interface org.onosproject.ui.UiTopoMapFactory
Produces a list of maps to be added to the topology view.
get() - Method in class org.onlab.util.BlockingAwareFuture
 
get() - Method in class org.onlab.util.BlockingBoolean
Gets the value of the blocking boolean.
get() - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
 
get() - Method in class org.onosproject.store.primitives.DefaultAtomicValue
 
get() - Method in interface org.onosproject.store.service.AsyncAtomicCounter
Returns the current value of the counter without modifying it.
get() - Method in interface org.onosproject.store.service.AsyncAtomicValue
Gets the current value.
get() - Method in interface org.onosproject.store.service.AtomicCounter
Returns the current value of the counter without modifying it.
get() - Method in interface org.onosproject.store.service.AtomicValue
Gets the current value.
get(int) - Method in class org.onlab.util.SlidingWindowCounter
Deprecated.
since 1.12
get(long, TimeUnit) - Method in class org.onlab.util.BlockingAwareFuture
 
get(JsonNode, int) - Static method in class org.onosproject.codec.JsonCodec
Gets a child Object Node from a parent by index.
get(ObjectNode, String) - Static method in class org.onosproject.codec.JsonCodec
Gets a child Object Node from a parent by name.
get(Class<T>) - Method in class org.onlab.osgi.DefaultServiceDirectory
 
get(Class<T>) - Method in interface org.onlab.osgi.ServiceDirectory
Returns implementation of the specified service class.
get(Class<T>) - Method in class org.onlab.rest.BaseResource
Returns reference to the specified service implementation.
get(Class<T>) - Static method in class org.onosproject.cli.AbstractShellCommand
Returns the reference to the implementation of the specified service.
get(Class<T>) - Method in class org.onosproject.net.driver.DefaultDriverHandler
 
get(Class<T>) - Method in interface org.onosproject.net.driver.DriverHandler
Returns the reference to the implementation of the specified service.
get(Class<T>) - Method in class org.onosproject.ui.RequestHandler
Returns an implementation of the specified service class.
get(Class<T>) - Method in class org.onosproject.ui.UiMessageHandler
Returns an implementation of the specified service class.
get(Object) - Method in class org.onlab.util.DefaultHashMap
 
get(Object) - Method in class org.onlab.util.ExtendedSet
Returns set element that is equal to the specified object.
get(Object) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
get(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
get(String) - Method in class org.onosproject.ui.chart.ChartModel.DataPoint
Returns the data value with the given series for this data point.
get(String) - Method in class org.onosproject.ui.table.TableModel.Row
Returns the value of the cell in the given column for this row.
get(String, boolean) - Method in class org.onosproject.net.config.Config
Gets the specified property as a boolean.
get(String, double) - Method in class org.onosproject.net.config.Config
Gets the specified property as a double.
get(String, int) - Method in class org.onosproject.net.config.Config
Gets the specified property as an integer.
get(String, long) - Method in class org.onosproject.net.config.Config
Gets the specified property as a long.
get(String, E, Class<E>) - Method in class org.onosproject.net.config.Config
Gets the specified property as an enum.
get(String, String) - Method in class org.onosproject.net.config.Config
Gets the specified property as a string.
get(Dictionary<?, ?>, String) - Static method in class org.onlab.util.Tools
Get property as a string value.
get(K) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
get(K) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
get(K) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
get(K) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Returns the value associated with key, or zero if there is no value associated with key.
get(K) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns the value (and version) to which the specified key is mapped, or null if this map contains no mapping for the key.
get(K) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns a collection of values associated with the specified key, if the key is not in the map it will return an empty collection.
get(K) - Method in interface org.onosproject.store.service.AtomicCounterMap
Returns the value associated with key, or zero if there is no value associated with key.
get(K) - Method in interface org.onosproject.store.service.ConsistentMap
Returns the value (and version) to which the specified key is mapped, or null if this map contains no mapping for the key.
get(K) - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns a collection of values associated with the specified key, if the key is not in the map it will return an empty collection.
get(K) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Returns the value mapped to the specified key.
get(K) - Method in interface org.onosproject.store.service.TransactionalMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(PiHandle) - Method in interface org.onosproject.net.pi.service.PiTranslationStore
Returns a PI translated entity for the given handle.
get(DocumentPath) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
get(DocumentPath) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Returns the value of the tree node at specified path.
get(DocumentPath) - Method in interface org.onosproject.store.service.DocumentTree
Returns a document tree node.
getAcknowledge() - Method in class org.onlab.packet.TCP
Gets acknowledge number.
getAction() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
Obtains the type of this bandwidth profile action object.
getActions() - Method in class org.onosproject.security.Permission
 
getActiveAlarms() - Method in interface org.onosproject.alarm.AlarmService
Returns all of the ACTIVE alarms.
getActiveAlarms(DeviceId) - Method in interface org.onosproject.alarm.AlarmService
Returns all of the ACTIVE alarms for a specific device.
getActiveFlowRuleCount(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleService
Deprecated.
since 2.1
getActiveFlowRuleCount(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleStore
Deprecated.
since 2.1
getActiveLinks() - Method in interface org.onosproject.net.link.LinkService
Returns a collection of all active infrastructure links.
getActivePartitionMembers(PartitionId) - Method in interface org.onosproject.cluster.ClusterMetadataProvider
Returns the set of controller nodes that are the active members for a partition.
getActorMI() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get Member Identifier.
getActorMN() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get Member Identifier.
getAddr() - Method in class org.onlab.packet.pim.PIMAddrGroup
Get the address of this encoded address.
getAddr() - Method in class org.onlab.packet.pim.PIMAddrSource
Get the address of this encoded address.
getAddr() - Method in class org.onlab.packet.pim.PIMAddrUnicast
Get the address of this encoded address.
getAddressFamilyId() - Method in class org.onlab.packet.RIPV2AuthEntry
 
getAddressFamilyId() - Method in class org.onlab.packet.RIPV2Entry
 
getAlarm(AlarmId) - Method in interface org.onosproject.alarm.AlarmService
Returns the alarm with the specified identifier.
getAlarmCounts() - Method in interface org.onosproject.alarm.AlarmService
Returns summary of alarms on all devices.
getAlarmCounts(DeviceId) - Method in interface org.onosproject.alarm.AlarmService
Returns summary of alarms on a given device.
getAlarms() - Method in interface org.onosproject.alarm.AlarmService
Returns all of the alarms.
getAlarms(Alarm.SeverityLevel) - Method in interface org.onosproject.alarm.AlarmService
Returns the alarms with the specified severity.
getAlarms(DeviceId) - Method in interface org.onosproject.alarm.AlarmService
Returns the alarm matching a given device, regardless of source within that device.
getAlarms(DeviceId, AlarmEntityId) - Method in interface org.onosproject.alarm.AlarmService
Returns the alarm for a given device and source.
getAlarmsForFlow(DeviceId, long) - Method in interface org.onosproject.alarm.AlarmService
Returns the alarm affecting a given flow.
getAlarmsForLink(ConnectPoint, ConnectPoint) - Method in interface org.onosproject.alarm.AlarmService
Returns the alarm affecting a given link.
getAlgAgility() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get Algorithm Agility.
getAll() - Method in class org.onosproject.ui.chart.ChartModel.DataPoint
Return the data value with the same order of series.
getAllBandwidthProfiles() - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Obtains all already configured bandwidth profiles from the device.
getAllGroups() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveStore
Fetch all groups from the store and their mapping to nextIds.
getAllMeters() - Method in interface org.onosproject.net.meter.MeterService
Fetches all the meters.
getAllMeters() - Method in interface org.onosproject.net.meter.MeterStore
Returns all meters stored in the store.
getAllMeters(DeviceId) - Method in interface org.onosproject.net.meter.MeterStore
Returns all meters stored in the store for a precise device.
getAllMeters(DeviceId, MeterScope) - Method in interface org.onosproject.net.meter.MeterStore
Returns all meters stored in the store for a precise device and scope.
getAllocatedResources(DiscreteResourceId, Class<T>) - Method in interface org.onosproject.net.resource.ResourceStore
Returns a collection of the resources which are children of the specified parent and whose type is the specified class.
getAllPartitionIds() - Method in interface org.onosproject.store.primitives.PartitionService
Returns the identifiers of all partitions.
getAndAdd(long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
 
getAndAdd(long) - Method in interface org.onosproject.store.service.AsyncAtomicCounter
Atomically adds the given value to the current value.
getAndAdd(long) - Method in interface org.onosproject.store.service.AtomicCounter
Atomically adds the given value to the current value.
getAndAdd(K, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
getAndAdd(K, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Adds delta to the value currently associated with key, and returns the old value.
getAndAdd(K, long) - Method in interface org.onosproject.store.service.AtomicCounterMap
Adds delta to the value currently associated with key, and returns the old value.
getAndDecrement(K) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
getAndDecrement(K) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Decrements by one the value currently associated with key, and returns the old value.
getAndDecrement(K) - Method in interface org.onosproject.store.service.AtomicCounterMap
Decrements by one the value currently associated with key, and returns the old value.
getAndIncrement() - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
 
getAndIncrement() - Method in interface org.onosproject.store.service.AsyncAtomicCounter
Atomically increment by one the current value.
getAndIncrement() - Method in interface org.onosproject.store.service.AtomicCounter
Atomically increment by one the current value.
getAndIncrement(K) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
getAndIncrement(K) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Increments by one the value currently associated with key, and returns the old value.
getAndIncrement(K) - Method in interface org.onosproject.store.service.AtomicCounterMap
Increments by one the value currently associated with key, and returns the old value.
getAndSet(V) - Method in class org.onosproject.store.primitives.DefaultAtomicValue
 
getAndSet(V) - Method in interface org.onosproject.store.service.AsyncAtomicValue
Atomically sets to the given value and returns the old value.
getAndSet(V) - Method in interface org.onosproject.store.service.AtomicValue
Atomically sets to the given value and returns the old value.
getAnnotatedValue(Annotated, String) - Static method in class org.onosproject.net.AnnotationKeys
Returns the value annotated object for the specified annotation key.
getAnnotations() - Method in class org.onosproject.ui.chart.ChartModel
Returns the annotations in this chart.
getAnnotations() - Method in class org.onosproject.ui.table.TableModel
Returns the annotations in this table.
getAppId(Short) - Method in interface org.onosproject.app.ApplicationIdStore
Returns an existing application id from a given id.
getAppId(Short) - Method in class org.onosproject.app.ApplicationIdStoreAdapter
 
getAppId(Short) - Method in interface org.onosproject.core.CoreService
Returns an existing application id from a given id.
getAppId(String) - Method in interface org.onosproject.app.ApplicationIdStore
Returns registered application id from the given name.
getAppId(String) - Method in class org.onosproject.app.ApplicationIdStoreAdapter
 
getAppId(String) - Method in interface org.onosproject.core.CoreService
Returns an existing application id from a given id.
getAppIds() - Method in interface org.onosproject.app.ApplicationIdStore
Returns the set of currently registered application identifiers.
getAppIds() - Method in class org.onosproject.app.ApplicationIdStoreAdapter
 
getAppIds() - Method in interface org.onosproject.core.CoreService
Returns the set of currently registered application identifiers.
getApplication(ApplicationId) - Method in interface org.onosproject.app.ApplicationService
Returns the application with the supplied application identifier.
getApplication(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
Returns the application with the supplied application identifier.
getApplication(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
getApplicationArchive(ApplicationId) - Method in interface org.onosproject.app.ApplicationService
Returns stream that contains the application OAR/JAR file contents.
getApplicationArchive(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
Returns stream that contains the application OAR/JAR file contents.
getApplicationArchive(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
getApplicationDescription(String) - Method in class org.onosproject.common.app.ApplicationArchive
Loads the application descriptor from the specified application archive stream and saves the stream in the appropriate application archive directory.
getApplicationInputStream(String) - Method in class org.onosproject.common.app.ApplicationArchive
Returns application archive stream for the specified application.
getApplicationNames() - Method in class org.onosproject.common.app.ApplicationArchive
Returns the set of installed application names.
getApplications() - Method in interface org.onosproject.app.ApplicationService
Returns the set of all installed applications.
getApplications() - Method in interface org.onosproject.app.ApplicationStore
Returns the set of all installed applications.
getApplications() - Method in class org.onosproject.store.app.DistributedApplicationStore
 
getAsFormattedStrings() - Method in class org.onosproject.ui.table.TableModel.Row
Returns the row as an array of formatted strings.
getAsImmutableSet() - Method in interface org.onosproject.store.service.AsyncDistributedSet
Returns the entries as a immutable set.
getAsString(String) - Method in class org.onosproject.ui.chart.ChartModel.DataPoint
Returns the value of the data point as a string, using the formatter appropriate for the series.
getAsStrings() - Method in class org.onosproject.ui.chart.ChartModel.DataPoint
Returns the row as an array of formatted strings.
getAsyncAtomicCounter(String) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of AsyncAtomicCounter with specified name.
getAsyncAtomicCounter(String) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of AsyncAtomicCounter with specified name.
getAsyncAtomicCounterNames() - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Returns the names of all created AsyncAtomicCounter instances.
getAsyncAtomicIdGenerator(String) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of AsyncAtomicIdGenerator with specified name.
getAsyncAtomicIdGenerator(String) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of AsyncAtomicIdGenerator with specified name.
getAsyncConsistentMapNames() - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Returns the names of all created AsyncConsistentMap instances.
getAsyncSetMultimap(String, Serializer) - Method in interface org.onosproject.store.service.PrimitiveService
Returns a set backed instance of AsyncConsistentMultimap with the specified name.
getAsyncSetMultimap(String, Serializer) - Method in interface org.onosproject.store.service.StorageService
Returns a set backed instance of AsyncConsistentMultimap with the specified name.
getAsyncTreeMap(String, Serializer) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of AsyncConsistentTreeMap with the specified name.
getAsyncTreeMap(String, Serializer) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of AsyncConsistentTreeMap with the specified name.
getAtomicCounter(String) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of AtomicCounter with specified name.
getAtomicCounter(String) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of AtomicCounter with specified name.
getAtomicIdGenerator(String) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of AtomicIdGenerator with specified name.
getAtomicIdGenerator(String) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of AtomicIdGenerator with specified name.
getAttribute(byte) - Method in class org.onlab.packet.RADIUS
Gets an attribute from the RADIUS packet.
getAttributeList(byte) - Method in class org.onlab.packet.RADIUS
Gets a list of attributes from the RADIUS packet.
getAuthenticator() - Method in class org.onlab.packet.RADIUS
Gets the authenticator.
getAuthEntry() - Method in class org.onlab.packet.RIP
 
getAuthLen() - Method in class org.onlab.packet.RIPV2AuthEntry
 
getAuxInfo() - Method in class org.onlab.packet.IGMPGroup
Get the auxillary info.
getAvailableDeviceCount() - Method in interface org.onosproject.net.device.DeviceService
Returns the number of currently available devices known to the system.
getAvailableDeviceCount() - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getAvailableDeviceCount() - Method in interface org.onosproject.net.device.DeviceStore
Returns the number of currently available devices known to the system.
getAvailableDeviceCount() - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getAvailableDevices() - Method in interface org.onosproject.net.device.DeviceService
Returns an iterable collection of all devices currently available to the system.
getAvailableDevices() - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getAvailableDevices() - Method in interface org.onosproject.net.device.DeviceStore
Returns an iterable collection of all devices currently available to the system.
getAvailableDevices() - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getAvailableDevices(Device.Type) - Method in interface org.onosproject.net.device.DeviceService
Returns an iterable collection of all devices currently available to the system by device type.
getAvailableDevices(Device.Type) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getAvailableDevices(Device.Type) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getAvailableIPs() - Method in interface org.onosproject.dhcp.DhcpService
Returns the list of all the available IPs with the server.
getAvailableIPs() - Method in interface org.onosproject.dhcp.DhcpStore
Returns the list of all the available IPs with the server.
getAvailableResources(DiscreteResourceId) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns resources that point available child resources under the specified resource.
getAvailableResources(DiscreteResourceId, Class<T>) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns available resources which are child resources of the specified parent and whose type is the specified type.
getAvailableResourceValues(DiscreteResourceId, Class<T>) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns available resource values which are the values of the child resource of the specified parent and whose type is the specified type.
getAvgPollInterval() - Method in class org.onosproject.net.statistic.PollInterval
Returns average poll interval value in seconds.
getBandwidthProfile(String) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Obtains an already configured bandwidth profile from the device.
getBasicParameterSet() - Method in class org.onlab.packet.EAPOLMkpdu
Provide Basic Parameter Set details.
getBBit() - Method in class org.onlab.packet.pim.PIMAddrGroup
Return the bBit.
getBehaviourClass(String) - Method in interface org.onosproject.net.driver.BehaviourClassResolver
Returns the class corresponding to the specified class name.
getBit(byte, int) - Static method in class org.onlab.util.ByteOperator
Obtains a specific bit value from a byte with given index number.
getBodyLength() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
getBodyLength() - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
getBodyLength() - Method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
 
getBodyLength() - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
getBodyLength() - Method in interface org.onlab.packet.EAPOLMkpduParameterSet
Retrieve Body Length field of Parameter Set.
getBodyLength() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
 
getBootFileName() - Method in class org.onlab.packet.DHCP
 
getBridges() - Method in interface org.onosproject.net.behaviour.BridgeConfig
Remove a bridge.
getBundledResource(Class<?>) - Static method in class org.onosproject.ui.lion.LionUtils
This method takes a class and returns a ResourceBundle which is loaded from a properties file with the same base name as the class.
getBundledResource(Class<?>, String) - Static method in class org.onosproject.ui.lion.LionUtils
This method returns a ResourceBundle which is loaded from a properties file with the specified base name from the same package as the specified class.
getBundledResource(String) - Static method in class org.onosproject.ui.lion.LionUtils
This method takes a fully qualified name and returns a ResourceBundle which is loaded from a properties file with that base name.
getBundledResource(String, Locale, ClassLoader) - Static method in class org.onosproject.ui.lion.LionUtils
This method takes a fully qualified name and returns a ResourceBundle which is loaded from a properties file with that base name.
getBytes() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
Serializes this instance.
getByteSize() - Method in class org.onlab.packet.pim.PIMAddrGroup
The size in bytes of a serialized address.
getByteSize() - Method in class org.onlab.packet.pim.PIMAddrSource
The size in bytes of a serialized address.
getByteSize() - Method in class org.onlab.packet.pim.PIMAddrUnicast
The size in bytes of a serialized address.
getBytesUtf8(String) - Static method in class org.onlab.util.Tools
Returns the UTF-8 encoded byte[] representation of a String.
getCandidates(String) - Method in interface org.onosproject.cluster.LeadershipService
Returns the candidate nodes for a given topic.
getCellId() - Method in class org.onosproject.net.behaviour.upf.PdrStats
Get the cell ID (index) of the dataplane PDR counter that produced this set of stats.
getChassisId() - Method in class org.onlab.packet.LLDP
 
getChassisIdByMac() - Method in class org.onlab.packet.ONOSLLDP
 
getChecksum() - Method in class org.onlab.packet.ICMP
 
getChecksum() - Method in class org.onlab.packet.ICMP6
Gets checksum.
getChecksum() - Method in class org.onlab.packet.IGMP
Get the checksum of this message.
getChecksum() - Method in class org.onlab.packet.IPv4
 
getChecksum() - Method in class org.onlab.packet.PIM
Get the checksum of this packet.
getChecksum() - Method in class org.onlab.packet.TCP
Gets checksum.
getChecksum() - Method in class org.onlab.packet.UDP
 
getChildren(DocumentPath) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
getChildren(DocumentPath) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Returns the children of node at specified path in the form of a mapping from child name to child value.
getChildren(DocumentPath) - Method in interface org.onosproject.store.service.DocumentTree
Returns the child values for this node.
getChildren(UiTopoLayoutId) - Method in interface org.onosproject.ui.UiTopoLayoutService
Returns the set of the child layouts of the specified layout.
getChildResources(DiscreteResourceId) - Method in interface org.onosproject.net.resource.ResourceStore
Returns a set of the child resources of the specified parent.
getChildResources(DiscreteResourceId, Class<T>) - Method in interface org.onosproject.net.resource.ResourceStore
Returns a set of the child resources of the specified parent and whose type is the specified class.
getCKN() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get CAK name.
getClasses() - Method in class org.onlab.rest.AbstractWebApplication
 
getClasses(Class<?>...) - Method in class org.onlab.rest.AbstractWebApplication
Returns the aggregate set of resources, writers and mappers combined with a default set of such web entities.
getClassName() - Method in class org.onosproject.security.Permission
 
getClientHardwareAddress() - Method in class org.onlab.packet.DHCP
 
getClientIPAddress() - Method in class org.onlab.packet.DHCP
 
getClt() - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
Gets Client Last Transaction Time.
getCluster(DeviceId) - Method in class org.onosproject.common.DefaultTopology
Returns the topology cluster that contains the given device.
getCluster(ClusterId) - Method in class org.onosproject.common.DefaultTopology
Returns the specified topology cluster.
getCluster(Topology, ClusterId) - Method in interface org.onosproject.net.topology.TopologyService
Returns the cluster with the specified ID.
getCluster(Topology, ClusterId) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the cluster of the specified topology.
getClusterDevices(TopologyCluster) - Method in class org.onosproject.common.DefaultTopology
Returns the set of cluster devices.
getClusterDevices(Topology, TopologyCluster) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of devices that belong to the specified cluster.
getClusterDevices(Topology, TopologyCluster) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the cluster of the specified topology.
getClusterLinks(TopologyCluster) - Method in class org.onosproject.common.DefaultTopology
Returns the set of cluster links.
getClusterLinks(Topology, TopologyCluster) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of links that form the specified cluster.
getClusterLinks(Topology, TopologyCluster) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the cluster of the specified topology.
getClusterMetadata() - Method in interface org.onosproject.cluster.ClusterMetadataProvider
Returns the current cluster metadata.
getClusterMetadata() - Method in interface org.onosproject.cluster.ClusterMetadataService
Returns the current cluster metadata.
getClusters() - Method in class org.onosproject.common.DefaultTopology
Returns the set of topology clusters.
getClusters(Topology) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of clusters in the specified topology.
getClusters(Topology) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the set of topology SCC clusters.
getClusterSecret() - Method in class org.onosproject.cluster.ClusterMetadata
Returns the cluster's shared secret.
getCmdType() - Method in class org.onlab.packet.RIP
 
getCmdType() - Method in class org.onlab.packet.RIPng
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6Option
Gets the code of this option.
getCode() - Method in class org.onlab.packet.dhcp.Dhcp6RelayOption
 
getCode() - Method in class org.onlab.packet.dhcp.DhcpOption
 
getCode() - Method in class org.onlab.packet.EAP
Gets the EAP code.
getCode() - Method in class org.onlab.packet.PPPoED
 
getCode() - Method in class org.onlab.packet.RADIUS
Gets the code.
getCodec(Class<T>) - Method in interface org.onosproject.codec.CodecService
Returns the JSON codec for the specified entity class.
getCodecs() - Method in interface org.onosproject.codec.CodecService
Returns the set of classes with currently registered codecs.
getCollectorMaxDelay() - Method in class org.onlab.packet.lacp.LacpCollectorTlv
Gets collector max delay.
getColumnIds() - Method in class org.onosproject.ui.table.TableModel
Returns the array of column IDs for this table model.
getColumnIds() - Method in class org.onosproject.ui.table.TableRequestHandler
Subclasses should return the array of column IDs with which to initialize their table model.
getCompilers() - Method in interface org.onosproject.net.intent.IntentExtensionService
Returns immutable set of bindings of currently registered intent compilers.
getCompiling() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Compiling intent count.
getComponentNames() - Method in interface org.onosproject.cfg.ComponentConfigService
Returns names of all components that have registered their configuration properties.
getConfig(S, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the configuration for the specified subject and configuration class if one is available; null otherwise.
getConfig(S, Class<C>) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getConfig(S, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigStore
Get the configuration of the given class and for the specified subject.
getConfigClass(String, String) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the configuration class with the specified key.
getConfigClass(String, String) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getConfigClasses(S) - Method in interface org.onosproject.net.config.NetworkConfigStore
Returns set of configuration classes available for the specified subject.
getConfigFactories() - Method in interface org.onosproject.net.config.NetworkConfigRegistry
Returns set of all registered configuration factories.
getConfigFactories() - Method in class org.onosproject.net.config.NetworkConfigRegistryAdapter
 
getConfigFactories(Class<S>) - Method in interface org.onosproject.net.config.NetworkConfigRegistry
Returns set of all configuration factories registered for the specified class of subject.
getConfigFactories(Class<S>) - Method in class org.onosproject.net.config.NetworkConfigRegistryAdapter
 
getConfigFactory(Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigRegistry
Returns the configuration factory that produces the specified class of configurations.
getConfigFactory(Class<C>) - Method in class org.onosproject.net.config.NetworkConfigRegistryAdapter
 
getConfigFactory(Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigStore
Returns the configuration factory for the specified configuration class.
getConfigs(S) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns all configurations for the specified subject.
getConfigs(S) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getConfiguration(String) - Method in interface org.onosproject.net.behaviour.ConfigGetter
Returns the string representation of a device configuration, returns a failure string if the configuration cannot be retrieved.
getConfiguredMembers(PartitionId) - Method in interface org.onosproject.store.primitives.PartitionService
Returns the set of controller nodes configured to be members of a partition.
getConnectedHosts(ConnectPoint) - Method in interface org.onosproject.net.host.HostService
Returns the set of hosts that attach to the specified connection point.
getConnectedHosts(ConnectPoint) - Method in interface org.onosproject.net.host.HostStore
Returns the set of hosts that attach to the specified connection point.
getConnectedHosts(ConnectPoint, boolean) - Method in interface org.onosproject.net.host.HostService
Returns the set of host that attach to the specified connect point.
getConnectedHosts(ConnectPoint, boolean) - Method in interface org.onosproject.net.host.HostStore
Returns the set of host that attach to the specified connect point.
getConnectedHosts(DeviceId) - Method in interface org.onosproject.net.host.HostService
Returns the set of hosts that attach to the specified device.
getConnectedHosts(DeviceId) - Method in interface org.onosproject.net.host.HostStore
Returns the set of hosts that attach to the specified device.
getConsensusNodes() - Method in interface org.onosproject.cluster.ClusterService
Returns the set of consensus nodes.
getControllerNodes() - Method in class org.onosproject.cluster.ClusterMetadata
Returns the collection of nodes that make up the cluster.
getControllers() - Method in interface org.onosproject.net.behaviour.ControllerConfig
Obtain the list of controller which are currently configured.
getControlPlaneConnectPoint() - Method in class org.onosproject.routing.config.RouterConfig
Deprecated.
Returns the routing control plane connect point.
getCount() - Method in class org.onosproject.cpman.MetricValue
Returns count value.
getCounters() - Method in interface org.onosproject.store.service.StorageAdminService
Returns information about all the atomic counters in the system.
getCounters(MetricFilter) - Method in class org.onlab.metrics.MetricsManager
Fetches the existing Counters.
getCounters(MetricFilter) - Method in interface org.onlab.metrics.MetricsService
Fetches the existing Counters.
getCpu() - Method in class org.onosproject.net.behaviour.DeviceSystemStats
Get cpu usage statistics.
getCriterion(Criterion.Type) - Method in class org.onosproject.net.flow.DefaultTrafficSelector
 
getCriterion(Criterion.Type) - Method in interface org.onosproject.net.flow.TrafficSelector
Returns the selection criterion for a particular type, if it exists in this traffic selector.
getCtrl() - Method in class org.onlab.packet.LLC
 
getCurrentFlowStatistic(ConnectPoint) - Method in interface org.onosproject.net.statistic.FlowStatisticStore
Fetches the current observed flow stats values.
getCurrentHopLimit() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets current hop limit.
getCurrentStatistic(ConnectPoint) - Method in interface org.onosproject.net.statistic.StatisticStore
Fetches the current observed stats values.
getData() - Method in class org.onlab.packet.Data
 
getData() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
getData() - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
getData() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
 
getData() - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
getData() - Method in class org.onlab.packet.dhcp.Dhcp6Option
Gets the data of this option.
getData() - Method in class org.onlab.packet.dhcp.Dhcp6RelayOption
 
getData() - Method in class org.onlab.packet.dhcp.DhcpOption
 
getData() - Method in class org.onlab.packet.EAP
Gets the EAP data.
getDataOffset() - Method in class org.onlab.packet.TCP
Gets offset.
getDataPoints() - Method in class org.onosproject.ui.chart.ChartModel
Returns all of data points in order.
getDataType() - Method in class org.onlab.packet.EAP
Gets the data type.
getDefault() - Method in class org.onlab.junit.ExceptionTest
 
getDefaultPipeconf() - Method in interface org.onosproject.net.behaviour.PiPipelineProgrammable
Returns the default pipeconf for this device, to be used when any other pipeconf is not available.
getDeltaStatisticsForPort(DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceService
Returns the port specific port delta statistics associated with the device and port.
getDeltaStatisticsForPort(DeviceId, PortNumber) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getDeltaStatisticsForPort(DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceStore
Returns the port delta statistics of the specified device and port.
getDescriptionNode(Document) - Static method in class org.onosproject.alarm.XmlEventParser
 
getDestinationAddress() - Method in class org.onlab.packet.IPv4
 
getDestinationAddress() - Method in class org.onlab.packet.IPv6
Gets destination address.
getDestinationAddress() - Method in class org.onlab.packet.ndp.Redirect
Gets destination address.
getDestinationMAC() - Method in class org.onlab.packet.Ethernet
Gets the destination MAC address.
getDestinationMACAddress() - Method in class org.onlab.packet.Ethernet
Gets the destination MAC address.
getDestinationPort() - Method in class org.onlab.packet.TCP
Gets TCP destination port.
getDestinationPort() - Method in class org.onlab.packet.UDP
 
getDevice(String) - Method in class org.onosproject.ui.topo.Highlights
Returns the device highlight for the given device identifier, or null if no match.
getDevice(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Returns the device with the specified identifier.
getDevice(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getDevice(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Returns the device with the specified identifier.
getDevice(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getDeviceCount() - Method in interface org.onosproject.net.device.DeviceService
Returns the number of infrastructure devices known to the system.
getDeviceCount() - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getDeviceCount() - Method in interface org.onosproject.net.device.DeviceStore
Returns the number of devices known to the system.
getDeviceCount() - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getDeviceDescription(DeviceId) - Method in interface org.onosproject.net.device.DeviceProviderService
Returns the specified device description.
getDeviceDescription(ProviderId, DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Returns the specified device description.
getDeviceDrivers() - Method in interface org.onosproject.net.driver.DriverService
Returns a map between all devices and their driver names.
getDeviceEgressLinks(DeviceId) - Method in interface org.onosproject.net.link.LinkService
Returns set of all infrastructure links leading from the specified device.
getDeviceEgressLinks(DeviceId) - Method in interface org.onosproject.net.link.LinkStore
Returns all links egressing from the specified device.
getDeviceId() - Method in class org.onosproject.cpman.ControlMetricsRequest
Obtains device identifier.
getDeviceIds(DomainId) - Method in interface org.onosproject.net.domain.DomainService
Returns the set of the device ids of the specified domain.
getDeviceIngressLinks(DeviceId) - Method in interface org.onosproject.net.link.LinkService
Returns set of all infrastructure links leading to the specified device.
getDeviceIngressLinks(DeviceId) - Method in interface org.onosproject.net.link.LinkStore
Returns all links ingressing from the specified device.
getDeviceKey(DeviceKeyId) - Method in interface org.onosproject.net.key.DeviceKeyService
Returns the device key using a device key identifier.
getDeviceKey(DeviceKeyId) - Method in interface org.onosproject.net.key.DeviceKeyStore
Returns the device key matching a device key identifier.
getDeviceKeys() - Method in interface org.onosproject.net.key.DeviceKeyService
Returns all device keys.
getDeviceKeys() - Method in interface org.onosproject.net.key.DeviceKeyStore
Returns all device keys.
getDeviceLinks(DeviceId) - Method in interface org.onosproject.net.link.LinkService
Returns set of all infrastructure links leading to and from the specified device.
getDevices() - Method in interface org.onosproject.net.device.DeviceService
Returns a collection of the currently known infrastructure devices.
getDevices() - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getDevices() - Method in interface org.onosproject.net.device.DeviceStore
Returns an iterable collection of all devices known to the system.
getDevices() - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getDevices(NodeId) - Method in interface org.onosproject.mastership.MastershipStore
Returns the devices that a controller instance is master of.
getDevices(Device.Type) - Method in interface org.onosproject.net.device.DeviceService
Returns a collection of the currently known infrastructure devices by device type.
getDevices(Device.Type) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getDevices(Device.Type) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getDevices(PiPipeconfId) - Method in interface org.onosproject.net.pi.service.PiPipeconfMappingStore
Retrieves the set of devices on which the given pipeconf is applied.
getDevicesOf(NodeId) - Method in interface org.onosproject.mastership.MastershipService
Deprecated.
1.6.0 Goldeneye release.
getDeviceString() - Method in class org.onlab.packet.ONOSLLDP
 
getDeviceSystemStats() - Method in interface org.onosproject.net.behaviour.DeviceSystemStatisticsQuery
Get System stats available for the device.
getDeviceTLV() - Method in class org.onlab.packet.ONOSLLDP
 
getDiffServ() - Method in class org.onlab.packet.IPv4
Gets the DiffServ octet (including the DSCP and ECN bits).
getDisjointPaths(DeviceId, DeviceId) - Method in class org.onosproject.common.DefaultTopology
Returns the set of pre-computed shortest disjoint path pairs between source and destination devices.
getDisjointPaths(DeviceId, DeviceId, Map<Link, Object>) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the set of shortest disjoint risk groups path pairs between source and destination devices.
getDisjointPaths(DeviceId, DeviceId, LinkWeigher) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the set of shortest disjoint path pairs between source and destination devices.
getDisjointPaths(DeviceId, DeviceId, LinkWeigher, Map<Link, Object>) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the set of shortest disjoint risk groups path pairs between source and destination devices.
getDisjointPaths(ElementId, ElementId) - Method in interface org.onosproject.net.topology.PathService
Returns the set of all disjoint shortest path pairs between the specified source and destination elements.
getDisjointPaths(ElementId, ElementId, Map<Link, Object>) - Method in interface org.onosproject.net.topology.PathService
Returns the set of all disjoint shortest path pairs between the specified source and destination elements and taking into consideration the provided risk profile.
getDisjointPaths(ElementId, ElementId, LinkWeigher) - Method in class org.onosproject.net.topology.AbstractPathService
 
getDisjointPaths(ElementId, ElementId, LinkWeigher) - Method in interface org.onosproject.net.topology.PathService
Returns the set of all disjoint shortest path pairs between the specified source and destination elements.
getDisjointPaths(ElementId, ElementId, LinkWeigher, Map<Link, Object>) - Method in class org.onosproject.net.topology.AbstractPathService
 
getDisjointPaths(ElementId, ElementId, LinkWeigher, Map<Link, Object>) - Method in interface org.onosproject.net.topology.PathService
Returns the set of all disjoint shortest path pairs between the specified source and destination elements and taking into consideration the provided risk profile.
getDisjointPaths(Topology, DeviceId, DeviceId) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of all disjoint shortest path pairs, precomputed in terms of hop-count, between the specified source and destination devices.
getDisjointPaths(Topology, DeviceId, DeviceId) - Method in interface org.onosproject.net.topology.TopologyStore
Computes and returns the set of disjoint shortest path pairs between src and dst.
getDisjointPaths(Topology, DeviceId, DeviceId, Map<Link, Object>) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of all disjoint shortest path pairs, precomputed in terms of hop-count, between the specified source and destination devices.
getDisjointPaths(Topology, DeviceId, DeviceId, Map<Link, Object>) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the set of pre-computed SRLG shortest paths between src and dest.
getDisjointPaths(Topology, DeviceId, DeviceId, LinkWeigher) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of all disjoint shortest path pairs, computed using the supplied edge-weight entity, between the specified source and destination devices.
getDisjointPaths(Topology, DeviceId, DeviceId, LinkWeigher) - Method in interface org.onosproject.net.topology.TopologyStore
Computes and returns the set of disjoint shortest path pairs between src and dst.
getDisjointPaths(Topology, DeviceId, DeviceId, LinkWeigher, Map<Link, Object>) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of all disjoint shortest path pairs, precomputed in terms of hop-count, between the specified source and destination devices.
getDisjointPaths(Topology, DeviceId, DeviceId, LinkWeigher, Map<Link, Object>) - Method in interface org.onosproject.net.topology.TopologyStore
Computes and returns the set of SRLG disjoint shortest path pairs between source and dst, given a mapping of edges to SRLG risk groups.
getDispatchTimeLimit() - Method in interface org.onosproject.event.EventDeliveryService
Returns the number of millis that an event sink has to process an event.
getDocProvider(String) - Method in interface org.onosproject.rest.ApiDocService
Returns the specified REST API documentation provider with the specified key.
getDocProviders() - Method in interface org.onosproject.rest.ApiDocService
Returns the set of all registered REST API documentation providers.
getDocumentTree(String, Serializer) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of AsyncDocumentTree with specified name.
getDocumentTree(String, Serializer) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of AsyncDocumentTree with specified name.
getDomain(DeviceId) - Method in interface org.onosproject.net.domain.DomainService
Returns a domain given a device id.
getDomainIds() - Method in interface org.onosproject.net.domain.DomainService
Returns the set of domains that have an associated topology.
GetDomainsCommand - Class in org.onosproject.cli.net
Gets the complete list of domain IDs.
GetDomainsCommand() - Constructor for class org.onosproject.cli.net.GetDomainsCommand
 
getDomainString() - Method in class org.onlab.packet.ONOSLLDP
 
getDomainTLV() - Method in class org.onlab.packet.ONOSLLDP
Gets the TLV associated with remote probing.
getDriver(String) - Method in interface org.onosproject.net.driver.DriverResolver
Returns the specified driver.
getDriver(String, String, String) - Method in interface org.onosproject.net.driver.DriverPrimordialResolver
Returns the driver that matches the specified primordial device discovery information.
getDriver(DeviceId) - Method in interface org.onosproject.net.driver.DriverService
Returns the driver for the specified device.
getDrivers() - Method in class org.onosproject.net.driver.DefaultDriverProvider
 
getDrivers() - Method in interface org.onosproject.net.driver.DriverProvider
Returns the set of driver types and behaviour implementations to be made available by this provider.
getDrivers() - Method in interface org.onosproject.net.driver.DriverRegistry
Returns the overall set of drivers being provided.
getDrivers() - Method in interface org.onosproject.net.driver.DriverService
Returns the overall set of drivers being provided.
getDrivers(Class<? extends Behaviour>) - Method in interface org.onosproject.net.driver.DriverService
Returns the set of drivers which support the specified behaviour.
getDropPrecedence() - Method in enum org.onlab.packet.DscpClass
Returns the corresponding drop precedence.
getDropPrecedence() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
Obtains the drop precedence corresponding to the REMARK action.
getDsap() - Method in class org.onlab.packet.LLC
 
getDscp() - Method in class org.onlab.packet.IPv4
Gets the DSCP value (6 bits).
getDscpClass() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
Obtains the DSCP class corresponding to the REMARK action.
getDst() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
Returns the destination transponder port.
getDst() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
Returns the destination transponder port.
getDst() - Method in class org.onosproject.net.intent.OpticalOduIntent
Returns the destination transponder port.
getDuid() - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
getDuidTime() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getDuidType() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getDuration() - Method in class org.onosproject.cpman.ControlMetricsRequest
Obtains projected time duration.
getEapolType() - Method in class org.onlab.packet.EAPOL
Gets the type.
getEcn() - Method in class org.onlab.packet.IPv4
Gets the ECN value (2 bits).
getEdgePoints() - Method in interface org.onosproject.net.edge.EdgePortService
Returns a collection of all edge point within the current topology.
getEdgePoints(DeviceId) - Method in interface org.onosproject.net.edge.EdgePortService
Returns a collection of all edge point for the specified device.
getEdges() - Method in class org.onlab.graph.AdjacencyListsGraph
 
getEdges() - Method in interface org.onlab.graph.Graph
Returns the set of edges comprising the graph.
getEdges() - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
getEdgesFrom(V) - Method in class org.onlab.graph.AdjacencyListsGraph
 
getEdgesFrom(V) - Method in interface org.onlab.graph.Graph
Returns all edges leading out from the specified source vertex.
getEdgesFrom(V) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
getEdgesTo(V) - Method in class org.onlab.graph.AdjacencyListsGraph
 
getEdgesTo(V) - Method in interface org.onlab.graph.Graph
Returns all edges leading towards the specified destination vertex.
getEdgesTo(V) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
getEgressBytes() - Method in class org.onosproject.net.behaviour.upf.PdrStats
Get the number of packet bytes that hit this counter in the dataplane egress pipeline.
getEgressLinks(ConnectPoint) - Method in interface org.onosproject.net.link.LinkService
Returns set of all infrastructure links leading from the specified connection point.
getEgressLinks(ConnectPoint) - Method in interface org.onosproject.net.link.LinkStore
Returns all links egressing from the specified connection point.
getEgressPkts() - Method in class org.onosproject.net.behaviour.upf.PdrStats
Get the number of packets that hit this counter in the dataplane egress pipeline.
getEnterpriseNumber() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getEntirePollInterval() - Method in class org.onosproject.net.statistic.PollInterval
Returns entire poll interval value in seconds.
getEtherType() - Method in class org.onlab.packet.Ethernet
Gets the Ethernet type.
getEvent(IntentData) - Static method in class org.onosproject.net.intent.IntentEvent
Creates an IntentEvent based on the state contained in the given intent data.
getEvent(IntentState, Intent) - Static method in class org.onosproject.net.intent.IntentEvent
Creates an IntentEvent based on the given state and intent.
getEventTime(String) - Static method in class org.onosproject.alarm.XmlEventParser
 
getEventTime(Document) - Static method in class org.onosproject.alarm.XmlEventParser
 
getExtensionInstruction(ExtensionTreatmentType) - Method in interface org.onosproject.net.behaviour.ExtensionTreatmentResolver
Gets an extension treatment instance of the specified type, if supported by the driver.
getExtensions() - Method in interface org.onosproject.ui.UiExtensionService
Returns the list of registered user interface extensions.
getExtensionSelector(ExtensionSelectorType) - Method in interface org.onosproject.net.behaviour.ExtensionSelectorResolver
Gets an extension selector instance of the specified type, if supported by the driver.
getExtraneousGroups(DeviceId) - Method in interface org.onosproject.net.group.GroupStore
Returns the extraneous groups associated with a device.
getFailed() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Failed intent count.
getFamily() - Method in class org.onlab.packet.pim.PIMAddrGroup
Get the IP family of this address: 4 or 6.
getFamily() - Method in class org.onlab.packet.pim.PIMAddrSource
Get the IP family of this address: 4 or 6.
getFamily() - Method in class org.onlab.packet.pim.PIMAddrUnicast
Get the IP family of this address: 4 or 6.
getFars() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Get all ForwardingActionRules currently installed on the UPF-programmable device.
getField(T, String) - Static method in class org.onlab.junit.TestUtils
Gets the field, bypassing scope restriction.
getFilteringObjQueue() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Returns all filtering objective that are waiting for the completion of previous objective with the same FilteringObjQueueKey.
getFilteringObjQueueHead() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
 
getFilters() - Method in interface org.onosproject.net.packet.PacketService
Get the list of packet filters present in ONOS.
getFirst() - Method in class org.onlab.util.UnmodifiableDeque
 
getFlag() - Method in class org.onlab.packet.bmp.BmpPeer
Returns Peer Flag.
getFlag() - Method in class org.onlab.packet.VXLAN
Return flags.
getFlags() - Method in class org.onlab.packet.DHCP
 
getFlags() - Method in class org.onlab.packet.IPv4
 
getFlags() - Method in class org.onlab.packet.TCP
Gets TCP flags.
getFloatProperty(Dictionary<?, ?>, String) - Static method in class org.onlab.util.Tools
Get Float property from the propertyName Return null if propertyName is not found.
getFlowEntries() - Method in interface org.onosproject.net.flow.FlowRuleProgrammable
Retrieves the collection of flow rule entries currently installed on the device.
getFlowEntries(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns the collection of flow entries applied on the specified device.
getFlowEntries(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleStore
Returns the flow entries associated with a device.
getFlowEntriesById(ApplicationId) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns a list of rules with this application ID.
getFlowEntriesByLiveType(DeviceId, FlowEntry.FlowLiveType) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns a list of rules filtered by device id and flow live type.
getFlowEntriesByState(DeviceId, FlowEntry.FlowEntryState) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns a list of rules filtered by device id and flow state.
getFlowEntry() - Method in class org.onosproject.net.DataPlaneEntity
Returns the flow entry.
getFlowEntry(FlowRule) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns the stored flow.
getFlowEntry(FlowRule) - Method in interface org.onosproject.net.flow.FlowRuleStore
Returns the stored flow.
getFlowLabel() - Method in class org.onlab.packet.IPv6
Gets flow label.
getFlowRuleCount() - Method in interface org.onosproject.net.flow.FlowRuleService
Returns the number of flow rules in the system.
getFlowRuleCount() - Method in interface org.onosproject.net.flow.FlowRuleStore
Returns the number of flow rules in the store.
getFlowRuleCount(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns the number of flow rules for the given device.
getFlowRuleCount(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleStore
Returns the number of flow rules for the given device in the store.
getFlowRuleCount(DeviceId, FlowEntry.FlowEntryState) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns the number of flow rules in the given state for the given device.
getFlowRuleCount(DeviceId, FlowEntry.FlowEntryState) - Method in interface org.onosproject.net.flow.FlowRuleStore
Returns the number of flow rules in the given state for the given device.
getFlowRulesByGroupId(ApplicationId, short) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns a list of rules filtered by application and group id.
GetFlowStatisticsCommand - Class in org.onosproject.cli.net
Fetches flow statistics with a flow type and instruction type.
GetFlowStatisticsCommand() - Constructor for class org.onosproject.cli.net.GetFlowStatisticsCommand
 
getFlowTableStatistics(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleService
Returns the collection of flow table statistics of the specified device.
getFormatter(String) - Method in class org.onosproject.ui.table.TableModel
Returns the cell formatter to use on values in the specified column.
getForwardingObjQueue() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Returns all forwarding objective that are waiting for the completion of previous objective with the same ForwardingObjQueueKey.
getForwardingObjQueueHead() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
 
getFragmentOffset() - Method in class org.onlab.packet.IPv4
 
getFragmentOffset() - Method in class org.onlab.packet.ipv6.Fragment
Gets the fragment offset of this header.
getFree() - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
Get free memory of device.
getGaddr() - Method in class org.onlab.packet.IGMPGroup
Get the multicast group address.
getGatewayIPAddress() - Method in class org.onlab.packet.DHCP
 
getGauges(MetricFilter) - Method in class org.onlab.metrics.MetricsManager
Fetches the existing Gauges.
getGauges(MetricFilter) - Method in interface org.onlab.metrics.MetricsService
Fetches the existing Gauges.
getGlyphs() - Method in interface org.onosproject.ui.UiExtensionService
Returns the list of registered user interface glyphs.
getGraph() - Method in class org.onosproject.common.DefaultTopology
Returns the backing topology graph.
getGraph(Topology) - Method in interface org.onosproject.net.topology.TopologyService
Returns the graph view of the specified topology.
getGraph(Topology) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the immutable graph view of the current topology.
getGroup() - Method in class org.onlab.packet.pim.PIMJoinPruneGroup
 
getGroup(Version) - Method in interface org.onosproject.cluster.MembershipService
Returns the membership group for the given version.
getGroup(DeviceId, GroupId) - Method in interface org.onosproject.net.group.GroupStore
Returns the stored group entry for an id.
getGroup(DeviceId, GroupKey) - Method in interface org.onosproject.net.group.GroupService
Returns a group object associated to an application cookie.
getGroup(DeviceId, GroupKey) - Method in interface org.onosproject.net.group.GroupStore
Returns the stored group entry.
getGroupCount(DeviceId) - Method in interface org.onosproject.net.group.GroupStore
Returns the number of groups for the specified device in the store.
getGroupEntry() - Method in class org.onosproject.net.DataPlaneEntity
Returns the group entry.
getGroups() - Method in class org.onlab.packet.IGMP
Get the list of IGMPGroups.
getGroups() - Method in interface org.onosproject.cluster.MembershipService
Returns the set of membership groups in the cluster.
getGroups() - Method in interface org.onosproject.net.group.GroupProgrammable
Queries the groups from the device.
getGroups(DeviceId) - Method in interface org.onosproject.net.group.GroupService
Returns all groups associated with the given device.
getGroups(DeviceId) - Method in interface org.onosproject.net.group.GroupStore
Returns the groups associated with a device.
getGroups(DeviceId, ApplicationId) - Method in interface org.onosproject.net.group.GroupService
Retrieves all groups created by an application in the specified device as seen by current controller instance.
getHandlerRegistrations() - Method in interface org.onosproject.net.neighbour.NeighbourResolutionService
Gets the neighbour message handlers that have been registered with the service.
getHardwareAddressLength() - Method in class org.onlab.packet.ARP
 
getHardwareAddressLength() - Method in class org.onlab.packet.DHCP
 
getHardwareType() - Method in class org.onlab.packet.ARP
 
getHardwareType() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getHardwareType() - Method in class org.onlab.packet.DHCP
 
getHeaderExtLength() - Method in class org.onlab.packet.ipv6.BaseOptions
Gets the extension length of this header.
getHeaderExtLength() - Method in class org.onlab.packet.ipv6.Routing
Gets the extension length of this header.
getHeaderLength() - Method in class org.onlab.packet.IPv4
 
getHistograms(MetricFilter) - Method in class org.onlab.metrics.MetricsManager
Fetches the existing Histograms.
getHistograms(MetricFilter) - Method in interface org.onlab.metrics.MetricsService
Fetches the existing Histograms.
getHoldTime() - Method in class org.onlab.packet.pim.PIMJoinPrune
Get the J/P hold time.
getHopCount() - Method in class org.onlab.packet.DHCP6
Gets the hop count of this DHCPv6 relay message.
getHopLimit() - Method in class org.onlab.packet.IPv6
Gets hop limit.
getHops() - Method in class org.onlab.packet.DHCP
 
getHost(String) - Method in class org.onosproject.ui.topo.Highlights
Returns the host highlight for the given host identifier, or null if no match.
getHost(HostId) - Method in interface org.onosproject.net.host.HostService
Returns the host with the specified identifier.
getHost(HostId) - Method in interface org.onosproject.net.host.HostStore
Returns the host with the specified identifer.
getHostCount() - Method in interface org.onosproject.net.host.HostService
Returns the number of end-station hosts known to the system.
getHostCount() - Method in interface org.onosproject.net.host.HostStore
Returns the number of hosts in the store.
getHosts() - Method in interface org.onosproject.net.behaviour.HostsDiscovery
Returns a collection of discovered host descriptions.
getHosts() - Method in interface org.onosproject.net.host.HostService
Returns a collection of all end-station hosts.
getHosts() - Method in interface org.onosproject.net.host.HostStore
Returns a collection of all hosts in the store.
getHosts(IpAddress) - Method in interface org.onosproject.net.host.HostStore
Returns the set of hosts with the specified IP address.
getHosts(MacAddress) - Method in interface org.onosproject.net.host.HostStore
Returns the set of hosts with the specified MAC address.
getHosts(VlanId) - Method in interface org.onosproject.net.host.HostStore
Returns the set of all hosts within the specified VLAN.
getHostsByIp(IpAddress) - Method in interface org.onosproject.net.host.HostService
Returns the set of hosts that have the specified IP address.
getHostsByMac(MacAddress) - Method in interface org.onosproject.net.host.HostService
Returns the set of hosts that have the specified MAC address.
getHostsByVlan(VlanId) - Method in interface org.onosproject.net.host.HostService
Returns the set of hosts that belong to the specified VLAN.
getIaAddress() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
getIaId() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Gets Identity Association ID.
getIaId() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Gets Identity Association ID.
getIaId() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
Gets Identity Association ID.
getIcmpCode() - Method in class org.onlab.packet.ICMP
 
getIcmpCode() - Method in class org.onlab.packet.ICMP6
Gets ICMP6 code.
getIcmpType() - Method in class org.onlab.packet.ICMP
 
getIcmpType() - Method in class org.onlab.packet.ICMP6
Gets ICMP6 type.
getId() - Method in class org.onosproject.cluster.DefaultPartition
 
getId() - Method in interface org.onosproject.cluster.Partition
Returns the partition identifier.
getId(String) - Method in interface org.onosproject.app.ApplicationService
Returns the registered id of the application with the given name.
getId(String) - Method in interface org.onosproject.app.ApplicationStore
Returns the registered id of the application with the given name.
getId(String) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
getIdBlock(String) - Method in interface org.onosproject.core.IdBlockStore
Returns a topic-unique block of ids.
getIdentification() - Method in class org.onlab.packet.IPv4
 
getIdentification() - Method in class org.onlab.packet.ipv6.Fragment
Gets the identification of this header.
getIdentifier() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getIdentifier() - Method in class org.onlab.packet.EAP
Gets the EAP identifier.
getIdentifier() - Method in class org.onlab.packet.ICMPEcho
Gets the identifier.
getIdentifier() - Method in class org.onlab.packet.RADIUS
Gets the identifier.
getIdGenerator(String) - Method in interface org.onosproject.core.CoreService
Returns an id generator for a given topic.
getIgmpType() - Method in class org.onlab.packet.IGMP
Get the IGMP message type.
getInfoString() - Method in class org.onlab.packet.LLDPOrganizationalTLV
Returns the value of information string.
getIngressBytes() - Method in class org.onosproject.net.behaviour.upf.PdrStats
Get the number of packet bytes that hit this counter in the dataplane ingress pipeline.
getIngressLinks(ConnectPoint) - Method in interface org.onosproject.net.link.LinkService
Returns set of all infrastructure links leading to the specified connection point.
getIngressLinks(ConnectPoint) - Method in interface org.onosproject.net.link.LinkStore
Returns all links ingressing to the specified connection point.
getIngressPkts() - Method in class org.onosproject.net.behaviour.upf.PdrStats
Get the number of packets that hit this counter in the dataplane ingress pipeline.
getInitialWeight() - Method in class org.onlab.graph.DefaultEdgeWeigher
 
getInitialWeight() - Method in interface org.onlab.graph.EdgeWeigher
Returns initial weight value (i.e.
getInitialWeight() - Method in class org.onosproject.net.topology.GeoDistanceLinkWeight
 
getInitialWeight() - Method in class org.onosproject.net.topology.HopCountLinkWeigher
 
getInitialWeight() - Method in class org.onosproject.net.topology.MetricLinkWeight
 
getInPort() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Gets inPort string.
getInputPorts(PortNumber) - Method in interface org.onosproject.net.behaviour.InternalConnectivity
Returns the set of input ports that can be connected to outputPort.
getInputPowerRange(PortNumber, T) - Method in interface org.onosproject.net.behaviour.PowerConfig
Get the expected input power range for the component, as optical components have different working input power ranges.
getInstallableIntents(Key) - Method in interface org.onosproject.net.intent.IntentService
Returns the list of the installable events associated with the specified top-level intent.
getInstallableIntents(Key) - Method in interface org.onosproject.net.intent.IntentStore
Returns the list of the installable events associated with the specified original intent.
getInstalled() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Installed intent count.
getInstaller(Class<T>) - Method in interface org.onosproject.net.intent.IntentExtensionService
Returns the installer for specific installable intent.
getInstallers() - Method in interface org.onosproject.net.intent.IntentExtensionService
Returns immutable set of binding of currently registered intent installers.
getInstalling() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Installing intent count.
getInstallReq() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns InstallReq intent count.
getInstance() - Static method in class org.onosproject.net.statistic.PollInterval
Returns the singleton PollInterval instance class for FlowStatisticService and other statistic services.
getIntAddress() - Method in class org.onlab.packet.bmp.BmpPeer
Returns Peer IP Address.
getIntegerProperty(Dictionary<?, ?>, String) - Static method in class org.onlab.util.Tools
Get Integer property from the propertyName Return null if propertyName is not found.
getIntegerProperty(Dictionary<?, ?>, String, int) - Static method in class org.onlab.util.Tools
Get Integer property from the propertyName Return default value if propertyName is not found.
getIntegrityCheck() - Method in class org.onlab.packet.ipv6.Authentication
Gets the integrity check value of this header.
getIntent(Key) - Method in interface org.onosproject.net.intent.IntentService
Fetches an intent based on its key.
getIntent(Key) - Method in interface org.onosproject.net.intent.IntentStore
Returns the intent with the specified identifier.
getIntentCount() - Method in interface org.onosproject.net.intent.IntentService
Returns the number of intents currently in the system.
getIntentCount() - Method in interface org.onosproject.net.intent.IntentStore
Returns the number of intents in the store.
getIntentData() - Method in interface org.onosproject.net.intent.IntentService
Returns an iterable of intent data objects currently in the system.
getIntentData(boolean, long) - Method in interface org.onosproject.net.intent.IntentStore
Returns an iterable of all intent data objects in the store.
getIntentData(Key) - Method in interface org.onosproject.net.intent.IntentStore
Returns the intent data object associated with the specified key.
getIntents() - Method in interface org.onosproject.net.behaviour.DomainIntentConfigurable
Retrieves all installed intend network domain.
getIntents() - Method in interface org.onosproject.net.intent.IntentService
Returns an iterable of intents currently in the system.
getIntents() - Method in interface org.onosproject.net.intent.IntentStore
Returns an iterable of all intents in the store.
getIntentsByAppId(ApplicationId) - Method in interface org.onosproject.net.intent.IntentService
Returns an iterable of all intents with this application ID.
getIntentState(Key) - Method in interface org.onosproject.net.intent.IntentService
Retrieves the state of an intent by its identifier.
getIntentState(Key) - Method in interface org.onosproject.net.intent.IntentStore
Returns the state of the specified intent.
getIntentType() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns intent Type.
getInterfaceByName(ConnectPoint, String) - Method in interface org.onosproject.net.intf.InterfaceService
Returns the interface with the given name.
getInterfaces() - Method in interface org.onosproject.net.behaviour.InterfaceConfig
Provides the interfaces configured on a device.
getInterfaces() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Get all UPF interface lookup entries currently installed on the UPF-programmable device.
getInterfaces() - Method in class org.onosproject.net.config.basics.InterfaceConfig
Retrieves all interfaces configured on this port.
getInterfaces() - Method in interface org.onosproject.net.intf.InterfaceService
Returns the set of all interfaces in the system.
getInterfaces() - Method in class org.onosproject.routing.config.RouterConfig
Deprecated.
Returns the list of interfaces enabled on this router.
getInterfacesByIp(IpAddress) - Method in interface org.onosproject.net.intf.InterfaceService
Returns the set of interfaces with the given IP address.
getInterfacesByPort(ConnectPoint) - Method in interface org.onosproject.net.intf.InterfaceService
Returns the set of interfaces configured on the given port.
getInterfacesByVlan(VlanId) - Method in interface org.onosproject.net.intf.InterfaceService
Returns the set of interfaces in the given VLAN.
GetInternalConnectivityOutputPortsCommand - Class in org.onosproject.cli.net
Lists possible output ports to which a given input port can be internally connected on a single device.
GetInternalConnectivityOutputPortsCommand() - Constructor for class org.onosproject.cli.net.GetInternalConnectivityOutputPortsCommand
 
getIp4Address() - Method in class org.onlab.packet.IpAddress
Gets the Ip4Address view of the IP address.
getIp4Prefix() - Method in class org.onlab.packet.IpPrefix
Gets the Ip4Prefix view of the IP prefix.
getIp6Address() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Gets IPv6 address.
getIp6Address() - Method in class org.onlab.packet.IpAddress
Gets the Ip6Address view of the IP address.
getIp6LinkAddress() - Method in class org.onlab.packet.DHCP6
Gets IPv6 link address.
getIp6PeerAddress() - Method in class org.onlab.packet.DHCP6
Gets IPv6 peer address.
getIp6Prefix() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Gets IPv6 address.
getIp6Prefix() - Method in class org.onlab.packet.IpPrefix
Gets the Ip6Prefix view of the IP prefix.
getipAddress() - Method in class org.onlab.packet.RIPV2Entry
 
getIpAssignmentFromAllocationMap(HostId) - Method in interface org.onosproject.dhcp.DhcpStore
Returns IpAssignment from map.
getIpPrecedence() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
Obtains the IP precedence corresponding to the REMARK action.
getIPPrecedence() - Method in enum org.onlab.packet.DscpClass
Returns the corresponding IP precedence.
getItems() - Method in class org.onosproject.ui.lion.LionBundle
Returns an immutable set of the items in this bundle.
getJoinPrunes() - Method in class org.onlab.packet.pim.PIMJoinPrune
Get the JoinPrune Group with all the joins and prunes.
getJoins() - Method in class org.onlab.packet.pim.PIMJoinPruneGroup
 
getJsonCodecContext() - Method in class org.onosproject.ui.UiMessageHandler
Obtain a CodecContext to be used in encoding and decoding objects that have a registered JsonCodec for their class.
getKey() - Method in class org.onlab.packet.lacp.LacpBaseTlv
Gets key.
getKeyId() - Method in class org.onlab.packet.RIPV2AuthEntry
 
getKeyServer() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get Key Server.
getKeyServerPriority() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get Key Server Priority.
getKShortestPaths(DeviceId, DeviceId) - Method in class org.onosproject.common.DefaultTopology
Lazily computes on-demand the k-shortest paths between source and destination devices.
getKShortestPaths(DeviceId, DeviceId, int) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the k-shortest paths between source and destination devices.
getKShortestPaths(DeviceId, DeviceId, LinkWeigher) - Method in class org.onosproject.common.DefaultTopology
Lazily computes on-demand the k-shortest paths between source and destination devices.
getKShortestPaths(DeviceId, DeviceId, LinkWeigher, int) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the k-shortest paths between source and destination devices.
getKShortestPaths(ElementId, ElementId) - Method in interface org.onosproject.net.topology.PathService
Returns the k-shortest paths between source and destination devices.
getKShortestPaths(ElementId, ElementId, LinkWeigher) - Method in class org.onosproject.net.topology.AbstractPathService
 
getKShortestPaths(ElementId, ElementId, LinkWeigher) - Method in interface org.onosproject.net.topology.PathService
Returns the k-shortest paths between source and destination devices.
getKShortestPaths(Topology, DeviceId, DeviceId) - Method in interface org.onosproject.net.topology.TopologyService
Returns the k-shortest paths between source and destination devices.
getKShortestPaths(Topology, DeviceId, DeviceId, LinkWeigher) - Method in interface org.onosproject.net.topology.TopologyService
Returns the k-shortest paths between source and destination devices.
getKShortestPaths(Topology, DeviceId, DeviceId, LinkWeigher) - Method in interface org.onosproject.net.topology.TopologyStore
Computes and returns the k-shortest paths between source and destination devices.
getKShortestPaths(Topology, DeviceId, DeviceId, LinkWeigher, int) - Method in interface org.onosproject.net.topology.TopologyService
Returns the k-shortest paths between source and destination devices.
getKShortestPaths(Topology, DeviceId, DeviceId, LinkWeigher, int) - Method in interface org.onosproject.net.topology.TopologyStore
Computes and returns the k-shortest paths between source and destination devices.
getLabel() - Method in class org.onlab.packet.MPLS
Returns the MPLS label.
getLabels() - Method in class org.onosproject.ui.chart.ChartModel
Returns all of labels in order.
getLacpVersion() - Method in class org.onlab.packet.lacp.Lacp
Gets LACP version.
getLast() - Method in class org.onlab.util.UnmodifiableDeque
 
getLastDataPoint() - Method in class org.onosproject.ui.chart.ChartModel
Returns the last element inside all of data points.
getLastUpdated(NodeId) - Method in interface org.onosproject.cluster.ClusterService
Deprecated.
in 1.12.0
getLastUpdatedInstant(NodeId) - Method in interface org.onosproject.cluster.ClusterService
Returns the system time when the availability state was last updated.
getLastUpdatedInstant(NodeId) - Method in interface org.onosproject.cluster.ClusterStore
Returns the system when the availability state was last updated.
getLastUpdatedInstant(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Indicates the time at which the given device connected or disconnected from this controller instance.
getLastUpdatedInstant(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getLastUpdatedInstant(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getLayout(RegionId) - Method in interface org.onosproject.ui.UiTopoLayoutService
Returns the layout which has the backing region identified by the given region identifier.
getLayout(UiTopoLayoutId) - Method in interface org.onosproject.ui.UiTopoLayoutService
Returns the layout with the specified identifier.
getLayouts() - Method in interface org.onosproject.ui.UiTopoLayoutService
Returns the set of available layouts (not including the root layout).
getLeader(String) - Method in interface org.onosproject.cluster.LeadershipService
Returns the node identifier that is the current leader for a topic.
getLeader(K, Function<K, Long>) - Method in interface org.onosproject.net.intent.WorkPartitionService
Returns the owner for a given identifier.
getLeaderBoard() - Method in interface org.onosproject.cluster.LeadershipAdminService
Returns the current leader board.
getLeadership(String) - Method in interface org.onosproject.cluster.LeadershipService
Returns the current leadership for a topic.
getLeadership(String) - Method in interface org.onosproject.cluster.LeadershipStore
Returns the current leadership for topic.
getLeadership(String) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
getLeadership(String) - Method in interface org.onosproject.store.service.AsyncLeaderElector
Returns the Leadership for the specified topic.
getLeadership(String) - Method in interface org.onosproject.store.service.LeaderElector
Returns the Leadership for the specified topic.
getLeaderships() - Method in interface org.onosproject.cluster.LeadershipStore
Return current leadership for all topics.
getLeaderships() - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
getLeaderships() - Method in interface org.onosproject.store.service.AsyncLeaderElector
Returns the current Leaderships for all topics.
getLeaderships() - Method in interface org.onosproject.store.service.LeaderElector
Returns the current Leaderships for all topics.
getLeaseTime() - Method in interface org.onosproject.dhcp.DhcpService
Returns the default lease time granted by the DHCP Server.
getLength() - Method in class org.onlab.packet.bmp.Bmp
Returns message length.
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6Option
Gets the length of this option.
getLength() - Method in class org.onlab.packet.dhcp.Dhcp6RelayOption
 
getLength() - Method in class org.onlab.packet.dhcp.DhcpOption
 
getLength() - Method in class org.onlab.packet.EAP
Gets the get packet length.
getLength() - Method in class org.onlab.packet.LLDPTLV
 
getLength() - Method in class org.onlab.packet.PPPoEDTag
 
getLength() - Method in class org.onlab.packet.RADIUSAttribute
Gets the attribute length.
getLength() - Method in class org.onlab.packet.UDP
 
getLink(String) - Method in class org.onosproject.ui.topo.Highlights
Returns the link highlight for the given link identifier, or null if no match.
getLink(ConnectPoint, ConnectPoint) - Method in interface org.onosproject.net.link.LinkService
Returns the infrastructure links between the specified source and destination connection points.
getLink(ConnectPoint, ConnectPoint) - Method in interface org.onosproject.net.link.LinkStore
Returns the link between the two end-points.
getLinkAddress() - Method in class org.onlab.packet.DHCP6
Gets the link address of this DHCPv6 relay message.
getLinkCount() - Method in interface org.onosproject.net.link.LinkService
Returns the count of all known infrastructure links.
getLinkCount() - Method in interface org.onosproject.net.link.LinkStore
Returns the number of links in the store.
getLinkLayerAddress() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getLinkLocalAddress(byte[]) - Static method in class org.onlab.packet.IPv6
Returns the auto-generated link local address using the mac address as parameter.
getLinks() - Method in interface org.onosproject.net.behaviour.LinkDiscovery
Returns set of discovered LinkDescription.
getLinks() - Method in interface org.onosproject.net.link.LinkService
Returns a collection of all known infrastructure links.
getLinks() - Method in interface org.onosproject.net.link.LinkStore
Returns an iterable collection of all links in the inventory.
getLinks(ConnectPoint) - Method in interface org.onosproject.net.link.LinkService
Returns set of all infrastructure links leading to and from the specified connection point.
getLionBundle(String) - Method in class org.onosproject.ui.UiMessageHandler
Returns the localization bundle with the given identifier, if we requested to have it cached during initialization; null otherwise.
getList(String, Function<String, T>) - Method in class org.onosproject.net.config.Config
Gets the specified array property as a list of items.
getList(String, Function<String, T>, List<T>) - Method in class org.onosproject.net.config.Config
Gets the specified array property as a list of items.
getLoad() - Method in class org.onosproject.cpman.MetricValue
Returns load value.
getLoad(NodeId, ControlMetricType, int, TimeUnit, String) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Obtains snapshot of control plane load of a specific resource with the projected range.
getLoad(NodeId, ControlMetricType, int, TimeUnit, Optional<DeviceId>) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Obtains snapshot of control plane load of a specific device with the projected range.
getLoad(NodeId, ControlMetricType, String) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Obtains snapshot of control plane load of a specific resource.
getLoad(NodeId, ControlMetricType, Optional<DeviceId>) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Obtains snapshot of control plane load of a specific device.
getLoadSync(NodeId, ControlMetricType, int, TimeUnit, String) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Synchronous version of getLoad.
getLoadSync(NodeId, ControlMetricType, int, TimeUnit, Optional<DeviceId>) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Synchronous version of getLoad.
getLoadSync(NodeId, ControlMetricType, String) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Synchronous version of getLoad.
getLoadSync(NodeId, ControlMetricType, Optional<DeviceId>) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Synchronous version of getLoad.
getLocalGroup() - Method in interface org.onosproject.cluster.MembershipService
Returns the group associated with the local member.
getLocalMember() - Method in interface org.onosproject.cluster.MembershipService
Returns the local member.
getLocalNode() - Method in class org.onosproject.cluster.ClusterMetadata
Returns the local controller node.
getLocalNode() - Method in interface org.onosproject.cluster.ClusterMetadataService
Returns the controller node representing this instance.
getLocalNode() - Method in interface org.onosproject.cluster.ClusterService
Returns the local controller node.
getLocalNode() - Method in interface org.onosproject.cluster.ClusterStore
Returns the local controller node.
getLocalPorts(Iterable<String>) - Method in interface org.onosproject.net.behaviour.BridgeConfig
Get logical/virtual ports by ifaceIds.
getLocalRole(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Returns the role of the local node for the specified device, without triggering master selection.
getLongPollInterval() - Method in class org.onosproject.net.statistic.PollInterval
Returns long poll interval value in seconds.
getLongProperty(Dictionary<?, ?>, String) - Static method in class org.onlab.util.Tools
Get Long property from the propertyName Return null if propertyName is not found.
getMacAddress() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Gets Mac address.
getMacAddress(byte[]) - Static method in class org.onlab.packet.IPv6
Returns the mac address from the auto-generated link local address.
getMacSecCapacity() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get MACSec Capacity.
getMacSecDesired() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get MACSec Desired.
getMapInfo() - Method in interface org.onosproject.store.service.StorageAdminService
Deprecated.
1.5.0 Falcon Release
getMapping(IntentId) - Method in interface org.onosproject.net.intent.IntentSetMultimap
Returns the set of intents mapped to a lower intent.
getMappings() - Method in class org.onosproject.net.config.basics.BasicRegionConfig
Returns the list of layout location mappings for where peer region nodes should be placed on the layout when viewing this region.
getMasklen() - Method in class org.onlab.packet.pim.PIMAddrGroup
Get the masklen of the group address.
getMasklen() - Method in class org.onlab.packet.pim.PIMAddrSource
Get the masklen of the group address.
getMaster(DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Returns the master for a device.
getMasterFor(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Returns the current master for a given device.
getMastership(DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Returns the mastership info for the given device.
getMastershipFor(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Returns the mastership info for the given device.
getMastershipTerm(DeviceId) - Method in interface org.onosproject.mastership.MastershipTermService
Returns the term number of mastership change occurred for given device.
getMatchingInterface(IpAddress) - Method in interface org.onosproject.net.intf.InterfaceService
Returns an interface that has an address that is in the same subnet as the given IP address.
getMatchingInterfaces(IpAddress) - Method in interface org.onosproject.net.intf.InterfaceService
Returns all interfaces that have an address that is in the same subnet as the given IP address.
getMaxMeters() - Method in interface org.onosproject.net.behaviour.MeterQuery
Get maximum meters available for the device.
getMaxRespField() - Method in class org.onlab.packet.IGMP
get the Max Resp Code.
getMCastMacAddress(byte[]) - Static method in class org.onlab.packet.IPv6
According to the RFC 2464, an IPv6 packet with a multicast destination address DST, consisting of the sixteen octets DST[1] through DST[16], is transmitted to the Ethernet multicast address whose first two octets are the value 3333 hexadecimal and whose last four octets are the last four octets of DST.
getMember(NodeId) - Method in interface org.onosproject.cluster.MembershipService
Returns the specified controller node.
getMemberID() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet.MemberDetails
 
getMembers() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
Member details.
getMembers() - Method in class org.onosproject.cluster.DefaultPartition
 
getMembers() - Method in interface org.onosproject.cluster.MembershipService
Returns the set of current cluster members in the local group.
getMembers() - Method in interface org.onosproject.cluster.Partition
Returns the controller nodes that are members of this partition.
getMembers(Version) - Method in interface org.onosproject.cluster.MembershipService
Returns the set of members in the given version.
getMemory() - Method in class org.onosproject.net.behaviour.DeviceSystemStats
Get memory usage statistics.
getMergedDriver(DeviceId, PiPipeconfId) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Returns the name of a driver that is equivalent to the base driver of the given device plus all the pipeline-specific behaviors exposed by the given pipeconf (previously registered using PiPipeconfService.register(PiPipeconf)).
getMessageNo() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet.MemberDetails
 
getMeter(DeviceId, MeterCellId) - Method in interface org.onosproject.net.meter.MeterService
Fetch the meter by the meter id.
getMeter(DeviceId, MeterId) - Method in interface org.onosproject.net.meter.MeterService
Deprecated.
in onos-2.5, Replace MeterId with MeterCellId
getMeter(MeterKey) - Method in interface org.onosproject.net.meter.MeterStore
Obtains a meter matching the given meter key.
getMeterFeatures() - Method in interface org.onosproject.net.meter.MeterProgrammable
Queries the meter features from the device.
getMeters() - Method in interface org.onosproject.net.meter.MeterProgrammable
Queries the meters from the device.
getMeters(MetricFilter) - Method in class org.onlab.metrics.MetricsManager
Fetches the existing Meters.
getMeters(MetricFilter) - Method in interface org.onlab.metrics.MetricsService
Fetches the existing Meters.
getMeters(DeviceId) - Method in interface org.onosproject.net.meter.MeterService
Fetches the meters by the device id.
getMeters(DeviceId, MeterScope) - Method in interface org.onosproject.net.meter.MeterService
Fetches the meters by the device id and scope.
getMetric() - Method in class org.onlab.packet.RIPngEntry
 
getMetric() - Method in class org.onlab.packet.RIPV2Entry
 
getMetricRegistry() - Method in class org.onlab.metrics.MetricsManager
Fetches existing metric registry.
getMetricRegistry() - Method in interface org.onlab.metrics.MetricsService
Fetches existing metric registry.
getMetrics() - Method in class org.onlab.metrics.MetricsManager
Fetches the existing Meters.
getMetrics() - Method in interface org.onlab.metrics.MetricsService
Fetches the existing metrics.
getMFlag() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets managed address configuration flag.
getMicroseconds() - Method in class org.onlab.packet.bmp.BmpPeer
Returns timestamp in micro second.
getMidPollInterval() - Method in class org.onosproject.net.statistic.PollInterval
Returns mid poll interval value in seconds.
getMirroringStatistics() - Method in interface org.onosproject.net.behaviour.MirroringConfig
Returns a collection of MirroringStatistics.
getMkaVersion() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get MKA Version.
getModulationScheme(PortNumber, T) - Method in interface org.onosproject.net.behaviour.ModulationConfig
Get the target Modulation Scheme on the component.
getMoreFragment() - Method in class org.onlab.packet.ipv6.Fragment
Gets the more fragment flag of this header.
getMsgType() - Method in class org.onlab.packet.DHCP6
Gets the message type of this DHCPv6 packet.
getMsgTypeStr(DHCP6.MsgType) - Static method in enum org.onlab.packet.DHCP6.MsgType
 
getName() - Method in class org.onlab.junit.LoggerAdapter
 
getName() - Method in class org.onlab.metrics.MetricsComponent
 
getName() - Method in interface org.onlab.metrics.MetricsComponentRegistry
Fetches the name of the Component.
getName() - Method in class org.onlab.metrics.MetricsFeature
Fetches the name of the Feature.
getName() - Method in class org.onosproject.cluster.ClusterMetadata
Returns the name of the cluster.
getName() - Method in class org.onosproject.security.Permission
 
getNameString() - Method in class org.onlab.packet.ONOSLLDP
 
getNameTLV() - Method in class org.onlab.packet.ONOSLLDP
 
getNativeVlanId(ConnectPoint) - Method in interface org.onosproject.net.intf.InterfaceService
Returns native VLAN configured on given connect point.
getNavLionBundle() - Method in interface org.onosproject.ui.UiExtensionService
Returns the navigation pane localization bundle.
getNewId() - Method in interface org.onosproject.core.IdGenerator
Returns a globally unique ID instance.
getNextGroup(Integer) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveStore
Fetch a next group from the store.
getNextHeader() - Method in class org.onlab.packet.ipv6.Authentication
 
getNextHeader() - Method in class org.onlab.packet.ipv6.BaseOptions
 
getNextHeader() - Method in class org.onlab.packet.ipv6.Fragment
 
getNextHeader() - Method in class org.onlab.packet.IPv6
 
getNextHeader() - Method in interface org.onlab.packet.ipv6.IExtensionHeader
Gets the type of next header.
getNextHeader() - Method in class org.onlab.packet.ipv6.Routing
 
getNextHop() - Method in class org.onlab.packet.RIPV2Entry
 
getNextId() - Method in class org.onosproject.core.IdBlock
Returns the next ID in the block.
getNextMappings() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Retrieve all nextObjective to group mappings known to this onos instance, in a format meant for display on the CLI, to help with debugging.
getNextMappings(NextGroup) - Method in interface org.onosproject.net.behaviour.Pipeliner
Retrieves a mapping of the nextObjective to the groups in the dataplane, and returns it in a form that can be displayed on the CLI.
getNextMappingsChain() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Retrieve all nextObjective to group mappings known to this onos instance, in a format meant for display via REST API, to help with debugging.
getNextObjQueue() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Returns all next objective that are waiting for the completion of previous objective with the same NextObjQueueKey.
getNextObjQueueHead() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
 
getNode(String) - Method in class org.onosproject.ui.topo.Highlights
Returns the node highlight (device or host) for the given element identifier, or null if no match.
getNode(NodeId) - Method in interface org.onosproject.cluster.ClusterService
Returns the specified controller node.
getNode(NodeId) - Method in interface org.onosproject.cluster.ClusterStore
Returns the specified controller node.
getNodes() - Method in class org.onosproject.cluster.ClusterMetadata
Deprecated.
getNodes() - Method in interface org.onosproject.cluster.ClusterService
Returns the set of current cluster members.
getNodes() - Method in interface org.onosproject.cluster.ClusterStore
Returns the set of current cluster members.
getNodes(DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Returns the master and backup nodes for a device.
getNodesFor(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Returns controllers connected to a given device, in order of preference.
getNonViableWeight() - Method in class org.onlab.graph.DefaultEdgeWeigher
 
getNonViableWeight() - Method in interface org.onlab.graph.EdgeWeigher
Returns weight of a link/path that should be skipped (can be considered as an infinite weight).
getNonViableWeight() - Method in class org.onosproject.net.topology.GeoDistanceLinkWeight
 
getNonViableWeight() - Method in class org.onosproject.net.topology.HopCountLinkWeigher
 
getNonViableWeight() - Method in class org.onosproject.net.topology.MetricLinkWeight
 
getNumberOfPartitions() - Method in interface org.onosproject.store.primitives.PartitionService
Returns the total number of partitions.
getOffset() - Method in class org.onlab.packet.RIPV2AuthEntry
 
getOFlag() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets other configuration flag.
getOpCode() - Method in class org.onlab.packet.ARP
 
getOpCode() - Method in class org.onlab.packet.DHCP
 
getOperations() - Method in class org.onosproject.net.flow.BatchOperation
Returns the operations in this object.
getOption(DHCP.DHCPOptionCode) - Method in class org.onlab.packet.DHCP
Gets a specific DHCP option parameter.
getOptionalTLVList() - Method in class org.onlab.packet.LLDP
 
getOptions() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
getOptions() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Gets options of IA Address option.
getOptions() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Gets sub-options.
getOptions() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Gets sub-options.
getOptions() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Gets options of IA Address option.
getOptions() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
Gets sub-options.
getOptions() - Method in class org.onlab.packet.DHCP
 
getOptions() - Method in class org.onlab.packet.DHCP6
Gets options from this DHCPv6 packet.
getOptions() - Method in class org.onlab.packet.IPv4
 
getOptions() - Method in class org.onlab.packet.ipv6.BaseOptions
Gets the options.
getOptions() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Gets the Neighbor Discovery Protocol packet options.
getOptions() - Method in class org.onlab.packet.ndp.NeighborSolicitation
Gets the Neighbor Discovery Protocol packet options.
getOptions() - Method in class org.onlab.packet.ndp.Redirect
Gets the Neighbor Discovery Protocol packet options.
getOptions() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets the Neighbor Discovery Protocol packet options.
getOptions() - Method in class org.onlab.packet.ndp.RouterSolicitation
Gets the Neighbor Discovery Protocol packet options.
getOptions() - Method in class org.onlab.packet.pim.PIMHello
 
getOptions() - Method in class org.onlab.packet.TCP
Gets TCP options.
getOptLength() - Method in class org.onlab.packet.pim.PIMHelloOption
 
getOptType() - Method in class org.onlab.packet.pim.PIMHelloOption
 
getOrDefault(Object, V) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
getOrDefault(String, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
getOrDefault(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
getOrDefault(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns the value (and version) to which the specified key is mapped, or the provided default value if this map contains no mapping for the key.
getOrDefault(K, V) - Method in interface org.onosproject.store.service.ConsistentMap
Returns the value (and version) to which the specified key is mapped, or the provided default value if this map contains no mapping for the key.
getOriginalDefaultAction(PiTableId) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
If the given table allows for mutable default actions, this method returns an action instance to be used when ONOS tries to remove a different default action previously set.
getOspfEnabled() - Method in class org.onosproject.routing.config.RouterConfig
Deprecated.
Returns whether OSPF is enabled on this router.
getOUI() - Method in class org.onlab.packet.LLDPOrganizationalTLV
Returns the value of the OUI.
getOutputPorts(PortNumber) - Method in interface org.onosproject.net.behaviour.InternalConnectivity
Returns the set of output ports that can be connected to inputPort.
getOverallCount() - Method in class org.onlab.util.SlidingWindowCounter
Returns the overall number of increments.
getOverallRate() - Method in class org.onlab.util.SlidingWindowCounter
Returns the overall rate.
getOverrideFlag() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Gets override flag.
getPacketLength() - Method in class org.onlab.packet.EAPOL
Gets the packet length.
getPacketType() - Method in class org.onlab.packet.DHCP
 
getParameterSet(byte) - Method in class org.onlab.packet.EAPOLMkpdu
Retrieve Parameter Set based on type.
getParameterSetType() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
getParameterSetType() - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
getParameterSetType() - Method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
 
getParameterSetType() - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
getParameterSetType() - Method in interface org.onlab.packet.EAPOLMkpduParameterSet
Retrieve Type of Parameter Set.
getParameterSetType() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
 
getParent() - Method in class org.onlab.packet.BasePacket
 
getParent() - Method in interface org.onlab.packet.IPacket
Obtain the parent packet.
getPartitions() - Method in class org.onosproject.cluster.ClusterMetadata
Deprecated.
since 1.14
getPaths(DeviceId, DeviceId) - Method in class org.onosproject.common.DefaultTopology
Returns the set of pre-computed shortest paths between source and destination devices.
getPaths(DeviceId, DeviceId, LinkWeigher) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the set of shortest paths between source and destination devices.
getPaths(DeviceId, DeviceId, LinkWeigher, int) - Method in class org.onosproject.common.DefaultTopology
Computes on-demand the set of shortest paths between source and destination devices, the set of returned paths will be no more than, maxPaths in size.
getPaths(ElementId, ElementId) - Method in interface org.onosproject.net.topology.PathService
Returns the set of all shortest paths between the specified source and destination elements.
getPaths(ElementId, ElementId, LinkWeigher) - Method in class org.onosproject.net.topology.AbstractPathService
 
getPaths(ElementId, ElementId, LinkWeigher) - Method in interface org.onosproject.net.topology.PathService
Returns the set of all shortest paths between the specified source and destination network elements.
getPaths(Topology, DeviceId, DeviceId) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of all shortest paths, precomputed in terms of hop-count, between the specified source and destination devices.
getPaths(Topology, DeviceId, DeviceId) - Method in interface org.onosproject.net.topology.TopologyStore
Returns the set of pre-computed shortest paths between src and dest.
getPaths(Topology, DeviceId, DeviceId, LinkWeigher) - Method in interface org.onosproject.net.topology.TopologyService
Returns the set of all shortest paths, computed using the supplied edge-weight entity, between the specified source and destination devices.
getPaths(Topology, DeviceId, DeviceId, LinkWeigher) - Method in interface org.onosproject.net.topology.TopologyStore
Computes and returns the set of shortest paths between src and dest.
getPayload() - Method in class org.onlab.packet.BasePacket
 
getPayload() - Method in interface org.onlab.packet.IPacket
Obtain the packet payload.
getPayloadLength() - Method in class org.onlab.packet.ipv6.Authentication
Gets the payload length of this header.
getPayloadLength() - Method in class org.onlab.packet.PPPoED
 
getPdrs() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Get all PacketDetectionRules currently installed on the UPF-programmable device.
getPeerAddress() - Method in class org.onlab.packet.DHCP6
Gets the peer address of this DHCPv6 relay message.
getPeerAs() - Method in class org.onlab.packet.bmp.BmpPeer
Returns Peer Autonomous System number.
getPeerBgpId() - Method in class org.onlab.packet.bmp.BmpPeer
Returns Peer Bgp Id.
getPeerDistinguisher() - Method in class org.onlab.packet.bmp.BmpPeer
Returns Peer Distinguisher.
getPeerLayouts(UiTopoLayoutId) - Method in interface org.onosproject.ui.UiTopoLayoutService
Returns the set of peer layouts of the specified layout.
getPeerListParameterSet() - Method in class org.onlab.packet.EAPOLMkpdu
Provide Live/Potential Peer List details.
getPending() - Method in interface org.onosproject.net.intent.IntentService
Returns the list of intent requests pending processing.
getPending() - Method in interface org.onosproject.net.intent.IntentStore
Returns the intent requests pending processing.
getPendingData() - Method in interface org.onosproject.net.intent.IntentStore
Returns the intent data objects that are pending processing.
getPendingData(boolean, long) - Method in interface org.onosproject.net.intent.IntentStore
Returns the intent data objects that are pending processing for longer than the specified duration.
getPendingData(Key) - Method in interface org.onosproject.net.intent.IntentStore
Returns the intent data object that are pending processing for a specfied key.
getPendingFlowObjectives() - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Retrieve all nextObjectives that are waiting to hear back from device drivers, and the forwarding-objectives or next-objectives that are waiting on the successful completion of the original next-objectives.
getPendingTransactions() - Method in interface org.onosproject.store.service.StorageAdminService
Returns all pending transactions.
getPermissions(ApplicationId) - Method in interface org.onosproject.app.ApplicationService
Returns the permissions currently granted to the applications.
getPermissions(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
Returns the permissions granted to the applications.
getPermissions(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
getPimMsgType() - Method in class org.onlab.packet.PIM
Return the PIM message type.
getPipeconf(DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Returns the pipeconf instance associated with the given device, if present.
getPipeconf(PiPipeconfId) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Returns the pipeconf instance associated with the given identifier, if present.
getPipeconfId(DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfMappingStore
Retrieves the id of the pipeconf associated to a given device.
getPipeconfs() - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Returns all pipeconfs registered.
getPolicer(PolicerId) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerConfigurable
 
getPolicers() - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerConfigurable
 
getPollInterval() - Method in class org.onosproject.net.statistic.PollInterval
Returns default poll interval value in seconds.
getPoolThreadExecutor() - Static method in class org.onlab.util.SharedExecutors
Returns the shared thread pool executor.
getPoolThreadExecutor() - Static method in class org.onlab.util.SharedScheduledExecutors
Returns the shared scheduled thread pool executor.
getPort() - Method in class org.onlab.packet.lacp.LacpBaseTlv
Gets port.
getPort() - Method in class org.onlab.packet.ONOSLLDP
 
getPort(ConnectPoint) - Method in interface org.onosproject.net.device.DeviceService
Returns the port with the specified connect point.
getPort(DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceService
Returns the port with the specified number and hosted by the given device.
getPort(DeviceId, PortNumber) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getPort(DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceStore
Returns the specified device port.
getPort(DeviceId, PortNumber) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getPortDeltaStatistics(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Returns the list of port delta statistics associated with the device.
getPortDeltaStatistics(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getPortDeltaStatistics(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Returns the list of delta port statistics of the specified device.
getPortDeltaStatistics(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getPortDescription(ProviderId, DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceStore
Returns the specified device port description.
getPortDescriptions(ProviderId, DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Returns the stream of port descriptions that belong to the specified device.
getPortDescString() - Method in class org.onlab.packet.ONOSLLDP
 
getPortDescTLV() - Method in class org.onlab.packet.ONOSLLDP
 
getPortId() - Method in class org.onlab.packet.LLDP
 
getPortNameString() - Method in class org.onlab.packet.ONOSLLDP
 
getPortNumbers() - Method in interface org.onosproject.net.behaviour.BridgeConfig
Get a collection of port.
getPortPriority() - Method in class org.onlab.packet.lacp.LacpBaseTlv
Gets port priority.
getPorts() - Method in interface org.onosproject.net.behaviour.BridgeConfig
Delete a logical/virtual port.
getPorts(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Returns the list of ports associated with the device.
getPorts(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getPorts(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Returns the list of ports that belong to the specified device.
getPorts(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getPorts(T) - Method in interface org.onosproject.net.behaviour.PowerConfig
Get the ports, which support PowerConfig operations for the specified component.
getPortStatistics(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Returns the list of port statistics associated with the device.
getPortStatistics(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getPortStatistics(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Returns the list of port statistics of the specified device.
getPortStatistics(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getPostFecBer(DeviceId, PortNumber) - Method in interface org.onosproject.net.behaviour.BitErrorRateState
Get the BER value post FEC.
getPreFecBer(DeviceId, PortNumber) - Method in interface org.onosproject.net.behaviour.BitErrorRateState
Get the BER value pre FEC.
getPreference(String, String) - Method in interface org.onosproject.ui.UiPreferencesService
Returns the named preference for the specified user.
getPreferences(String) - Method in interface org.onosproject.ui.UiPreferencesService
Returns an immutable copy of the preferences for the specified user.
getPreferredLifetime() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Gets preferred lifetime.
getPreferredLifetime() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Gets preferred lifetime.
getPrefix() - Method in class org.onlab.packet.RIPngEntry
 
getPrefix() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
Get the IPv4 prefix of this UPF interface.
getPrefixLen() - Method in class org.onlab.packet.RIPngEntry
 
getPrefixLength() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Gets prefix length.
getPreviousFlowStatistic(ConnectPoint) - Method in interface org.onosproject.net.statistic.FlowStatisticStore
Fetches the current observed flow stats values.
getPreviousStatistic(ConnectPoint) - Method in interface org.onosproject.net.statistic.StatisticStore
Fetches the previous observed stats values.
getPrintableGrantedPermissions(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
Returns sorted granted permission Map.
getPrintableRequestedPermissions(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
Returns sorted requested permission Map.
getPrintableSpecifiedPermissions(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
Returns sorted developer specified permission Map.
getPriorityCode() - Method in class org.onlab.packet.Ethernet
Gets the priority code.
getProcessors() - Method in interface org.onosproject.net.packet.PacketService
Returns priority bindings of all registered packet processor entries.
getProperties() - Method in class org.onosproject.net.flow.AbstractExtension
 
getProperties() - Method in interface org.onosproject.net.flow.Extension
Gets a list of all properties on the extension.
getProperties(String) - Method in interface org.onosproject.cfg.ComponentConfigService
Returns configuration properties of the named components.
getProperties(String) - Method in interface org.onosproject.cfg.ComponentConfigStore
Returns set of component configuration property names.
getProperties(String) - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
 
getProperty(String) - Method in class org.onosproject.net.driver.DefaultDriver
 
getProperty(String) - Method in interface org.onosproject.net.driver.Driver
Gets the value of given property name.
getProperty(String, String) - Method in interface org.onosproject.cfg.ComponentConfigService
Returns configuration property of the named components.
getProperty(String, String) - Method in interface org.onosproject.cfg.ComponentConfigStore
Returns the string value of the given component configuration property.
getProperty(String, String) - Method in interface org.onosproject.net.driver.Driver
Gets the value of given property name.
getProperty(String, String) - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
 
getPropertyValue(String) - Method in class org.onosproject.net.flow.AbstractExtension
 
getPropertyValue(String) - Method in interface org.onosproject.net.flow.Extension
Gets a property value of an extension.
getProtectionEndpoint(String) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Retrieves ProtectedTansportEndpoint information (=virtual Port ConnectPoint and ProtectedTransportEndpointState pair) on the Device.
getProtectionEndpointConfig(ConnectPoint) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Retrieves ProtectedTransportEndpointDescription with specified ID.
getProtectionEndpointConfigs() - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Retrieves ProtectedTransportEndpointDescriptions on the Device.
getProtectionEndpointState(ConnectPoint) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Retrieves ProtectedTransportEndpointState on the Device.
getProtectionEndpointStates() - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Retrieves ProtectedTransportEndpointStates on the Device.
getProtocol() - Method in class org.onlab.packet.IPv4
 
getProtocolAddressLength() - Method in class org.onlab.packet.ARP
 
getProtocolType() - Method in class org.onlab.packet.ARP
 
getProvider(String) - Method in class org.onosproject.net.provider.AbstractProviderRegistry
Returns the provider registered with the specified scheme.
getProvider(DeviceId) - Method in class org.onosproject.net.provider.AbstractProviderRegistry
Returns the provider for the specified device ID based on URI scheme.
getProvider(ProviderId) - Method in class org.onosproject.net.provider.AbstractProviderRegistry
Returns the provider registered with the specified provider ID or null if none is found for the given provider family and default fall-back is not supported.
getProviders() - Method in interface org.onosproject.net.driver.DriverAdminService
Returns the set of driver providers currently registered.
getProviders() - Method in class org.onosproject.net.provider.AbstractProviderRegistry
 
getProviders() - Method in interface org.onosproject.net.provider.ProviderRegistry
Returns a set of currently registered provider identities.
getProxyFactory(Class<T>, Serializer) - Method in interface org.onosproject.cluster.ProxyService
Returns a new proxy factory for the given type.
getProxyFactory(Class<T>, Serializer) - Method in interface org.onosproject.mastership.MastershipProxyService
Returns a proxy factory for the given type.
getProxyFor(NodeId) - Method in interface org.onosproject.cluster.ProxyFactory
Returns the proxy for the given peer.
getProxyFor(DeviceId) - Method in interface org.onosproject.mastership.MastershipProxyFactory
Returns the proxy for the given device.
getPrunes() - Method in class org.onlab.packet.pim.PIMJoinPruneGroup
 
getQinQPriorityCode() - Method in class org.onlab.packet.Ethernet
Gets the QinQ priority code.
getQinQTPID() - Method in class org.onlab.packet.Ethernet
Gets the QinQ TPID.
getQinQVID() - Method in class org.onlab.packet.Ethernet
Gets the QinQ VLAN ID.
getQos(QosDescription) - Method in interface org.onosproject.net.behaviour.QosConfigBehaviour
Obtain a qos configured on a device.
getQoses() - Method in interface org.onosproject.net.behaviour.QosConfigBehaviour
Obtain all qoses configured on a device.
getQrv() - Method in class org.onlab.packet.IGMPQuery
Get the Querier Robustness Variable.
getQueue(QueueDescription) - Method in interface org.onosproject.net.behaviour.QueueConfigBehaviour
Obtain a queue configured on a device.
getQueues() - Method in interface org.onosproject.net.behaviour.QueueConfigBehaviour
Obtain all queues configured on a device.
getQueueStats() - Method in interface org.onosproject.store.service.StorageAdminService
Returns statistics for all the work queues in the system.
getRate() - Method in class org.onosproject.cpman.MetricValue
Returns rate value.
getRawData() - Method in class org.onlab.packet.RIP
 
getRBit() - Method in class org.onlab.packet.pim.PIMAddrSource
Return the rBit.
getReachableTime() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets reachable time.
getReadableIdentifier() - Method in class org.onlab.packet.RADIUS
Get the identifier in a readable format.
getRebindingTime() - Method in interface org.onosproject.dhcp.DhcpService
Returns the default rebinding time granted by the DHCP Server.
getRecompiling() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Recompiling intent count.
getRecordType() - Method in class org.onlab.packet.IGMPMembership
Gets the IGMP record type.
getRegion(RegionId) - Method in interface org.onosproject.net.region.RegionService
Returns the region with the specified identifier.
getRegion(RegionId) - Method in interface org.onosproject.net.region.RegionStore
Returns the region with the specified identifier.
getRegionDevices(RegionId) - Method in interface org.onosproject.net.region.RegionService
Returns the set of devices that belong to the specified region.
getRegionDevices(RegionId) - Method in interface org.onosproject.net.region.RegionStore
Returns the set of devices that belong to the specified region.
getRegionForDevice(DeviceId) - Method in interface org.onosproject.net.region.RegionService
Returns the region to which the specified device belongs.
getRegionForDevice(DeviceId) - Method in interface org.onosproject.net.region.RegionStore
Returns the region to which the specified device belongs.
getRegionHosts(RegionId) - Method in interface org.onosproject.net.region.RegionService
Returns the set of hosts that belong to the specified region.
getRegions() - Method in interface org.onosproject.net.region.RegionService
Returns set of all regions.
getRegions() - Method in interface org.onosproject.net.region.RegionStore
Returns set of all regions.
getRegisteredApplications() - Method in interface org.onosproject.app.ApplicationService
Returns the set of all installed applications.
getRegisteredResources(DiscreteResourceId) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns resources registered under the specified resource.
getRenewalTime() - Method in interface org.onosproject.dhcp.DhcpService
Returns the default renewal time granted by the DHCP Server.
getReplicaInfoFor(DeviceId) - Method in interface org.onosproject.store.flow.ReplicaInfoService
Returns the placement information for given Device.
getRequests() - Method in interface org.onosproject.net.packet.PacketService
Returns list of all existing requests ordered by priority.
getReserved() - Method in class org.onlab.packet.PIM
Get the reserved field.
getReserved() - Method in class org.onlab.packet.RIP
 
getReserved() - Method in class org.onlab.packet.RIPng
 
getResourceAllocations(DiscreteResourceId, Class<T>) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns allocated resources being as children of the specified parent and being the specified resource type.
getResourceAllocations(ResourceConsumer) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns resources allocated to the specified consumer.
getResourceAllocations(ResourceId) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns resource allocations of the specified resource.
getResourceAllocations(ResourceId) - Method in interface org.onosproject.net.resource.ResourceStore
Returns the resource consumers to whom the specified resource is allocated.
getResourceName() - Method in class org.onosproject.cpman.ControlMetricsRequest
Obtains resource name.
getResources(ResourceConsumer) - Method in interface org.onosproject.net.resource.ResourceStore
Returns a collection of the resources allocated to the specified consumer.
getResv() - Method in class org.onlab.packet.IGMPQuery
Get the reserved field.
getRetransmitTimer() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets retransmission timer.
getRole() - Method in interface org.onosproject.net.device.DeviceHandshaker
Returns the last known mastership role agreed by the device for this node.
getRole(String) - Method in class org.onosproject.common.app.ApplicationArchive
 
getRole(NodeId) - Method in class org.onosproject.mastership.MastershipInfo
Returns the current role for the given node.
getRole(NodeId, DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Returns the role of a device for a specific controller instance.
getRole(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Returns the current mastership role for the specified device.
getRole(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getRole(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
getRoles(MastershipRole) - Method in class org.onosproject.mastership.MastershipInfo
Returns the list of nodes with the given role.
getRootLayout() - Method in interface org.onosproject.ui.UiTopoLayoutService
Returns the top-level root layout, which always exists and cannot be removed or associated directly with a region.
getRootPath() - Method in class org.onosproject.common.app.ApplicationArchive
Returns the root directory where apps directory is contained.
getRouterConfigurations(NetworkConfigService, ApplicationId) - Static method in class org.onosproject.routing.config.RoutingConfiguration
Retrieves the router configurations.
getRouterFlag() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Gets router flag.
getRouterLifetime() - Method in class org.onlab.packet.ndp.RouterAdvertisement
Gets router lifetime.
getRouters() - Method in class org.onosproject.routing.config.RoutersConfig
Gets the router configurations.
getRoutes() - Method in interface org.onosproject.net.mcast.McastStore
Deprecated.
Gets the set of all known multicast routes.
getRoutes() - Method in interface org.onosproject.net.mcast.MulticastRouteService
Deprecated.
Gets all multicast routes in the system.
getRouteTag() - Method in class org.onlab.packet.RIPngEntry
 
getRouteTag() - Method in class org.onlab.packet.RIPV2Entry
 
getRoutingData() - Method in class org.onlab.packet.ipv6.Routing
Gets the routing data.
getRoutingType() - Method in class org.onlab.packet.ipv6.Routing
Gets the routing type of this header.
getRows() - Method in class org.onosproject.ui.table.TableModel
Returns the raw TableModel.Row representation of the rows in this table.
getRtEntries() - Method in class org.onlab.packet.RIP
 
getRtEntries() - Method in class org.onlab.packet.RIPng
 
getSafe(Enum<?>) - Method in class org.onosproject.ui.lion.LionBundle
Converts the given enum constant to lowercase and then uses that as the key to invoke LionBundle.getSafe(String).
getSafe(String) - Method in class org.onosproject.ui.lion.LionBundle
Returns the localized value for the given key, or, if no such mapping exists, returns the key wrapped in '%' characters.
getSBit() - Method in class org.onlab.packet.pim.PIMAddrSource
Return the sparse bit.
getSci() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To get SCI.
getSeconds() - Method in class org.onlab.packet.bmp.BmpPeer
Returns timestamp in sec.
getSeconds() - Method in class org.onlab.packet.DHCP
 
getSecurityParamIndex() - Method in class org.onlab.packet.ipv6.Authentication
Gets the security parameter index of this header.
getSecurityParamIndex() - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
Gets the security parameter index of this header.
getSecurityService() - Static method in class org.onosproject.security.SecurityUtil
 
getSegmentsLeft() - Method in class org.onlab.packet.ipv6.Routing
Gets the number of remaining route segments of this header.
getSenderHardwareAddress() - Method in class org.onlab.packet.ARP
 
getSenderProtocolAddress() - Method in class org.onlab.packet.ARP
 
getSequence() - Method in class org.onlab.packet.ipv6.Authentication
Gets the sequence number of this header.
getSequence() - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
Gets the sequence number of this header.
getSequence() - Method in class org.onlab.packet.RIPV2AuthEntry
 
getSequence() - Method in class org.onlab.packet.TCP
Gets sequence number.
getSequenceNum() - Method in class org.onlab.packet.ICMPEcho
Gets the sequence number.
getSeries() - Method in class org.onosproject.ui.chart.ChartModel
Returns all of series.
getSeries() - Method in class org.onosproject.ui.chart.ChartRequestHandler
Subclasses should return the array of series with which to initialize their chart model.
getServerIPAddress() - Method in class org.onlab.packet.DHCP
 
getServerName() - Method in class org.onlab.packet.DHCP
 
getService(Class<T>) - Static method in class org.onlab.osgi.DefaultServiceDirectory
Returns the reference to the implementation of the specified service.
getService(Class<T>) - Method in class org.onosproject.cli.AbstractShellCommand
 
getService(Class<T>) - Method in interface org.onosproject.codec.CodecContext
Returns reference to the specified service implementation.
getService(Class<T>) - Method in class org.onosproject.net.config.BaseConfig
 
getService(Class<T>) - Method in class org.onosproject.rest.AbstractWebResource
 
getSessionId() - Method in class org.onlab.packet.PPPoED
 
getSig() - Method in class org.onlab.packet.ONOSLLDP
 
getSignalType() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
Returns the ODU signal type.
getSignalType() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
Returns the ODU signal type.
getSignalType() - Method in class org.onosproject.net.intent.OpticalOduIntent
Returns the CltSignalType signal type.
getSigTLV() - Method in class org.onlab.packet.ONOSLLDP
 
getSingleThreadExecutor() - Static method in class org.onlab.util.SharedExecutors
Returns the shared single thread executor.
getSingleThreadExecutor() - Static method in class org.onlab.util.SharedScheduledExecutors
Returns the shared scheduled single thread executor.
getSink(Class<E>) - Method in class org.onosproject.event.DefaultEventSinkRegistry
 
getSink(Class<E>) - Method in interface org.onosproject.event.EventSinkRegistry
Returns the event sink associated with the specified event class.
getSinks() - Method in class org.onosproject.event.DefaultEventSinkRegistry
 
getSinks() - Method in interface org.onosproject.event.EventSinkRegistry
Returns the set of all event classes for which sinks are presently registered.
getSize() - Method in class org.onosproject.core.IdBlock
Returns the block size.
getSize(ObjectNode, Class<?>, Type, Annotation[], MediaType) - Method in class org.onlab.rest.JsonBodyWriter
 
getSolicitedFlag() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Gets solicited flag.
getSolicitNodeAddress(byte[]) - Static method in class org.onlab.packet.IPv6
According to the RFC 4291, the solicitation node addresses are formed by taking the low-order 24 bits of an address (unicast or anycast) and appending those bits to the prefix FF02:0:0:0:0:1:FF00::/104.
getSortedDeviceKeys(DeviceKeyService) - Method in class org.onosproject.cli.net.DeviceKeyListCommand
Returns the list of devices keys sorted using the device key identifier.
getSortedDevices(DeviceService) - Static method in class org.onosproject.cli.net.DevicesListCommand
Returns the list of devices sorted using the device ID URIs.
getSortedFlows(DeviceService, FlowRuleService, CoreService) - Method in class org.onosproject.cli.net.FlowsListCommand
Returns the list of devices sorted using the device ID URIs.
getSortedGroups(DeviceService, GroupService) - Method in class org.onosproject.cli.net.GroupsListCommand
Returns the list of devices sorted using the device ID URIs.
getSortedHosts(HostService) - Method in class org.onosproject.cli.net.HostsListCommand
Returns the list of devices sorted using the device ID URIs.
getSortedRegions(RegionService) - Method in class org.onosproject.cli.net.RegionListCommand
Returns the list of regions sorted using the region identifier.
getSortedTableStats(DeviceService, FlowRuleService) - Method in class org.onosproject.cli.net.TableStatisticsCommand
Returns the list of table statistics sorted using the device ID URIs and table IDs.
getSourceAddress() - Method in class org.onlab.packet.IPv4
 
getSourceAddress() - Method in class org.onlab.packet.IPv6
Gets source address.
getSourceMAC() - Method in class org.onlab.packet.Ethernet
Gets the source MAC address.
getSourceMACAddress() - Method in class org.onlab.packet.Ethernet
Gets the source MAC address.
getSourcePort() - Method in class org.onlab.packet.TCP
Gets TCP source port.
getSourcePort() - Method in class org.onlab.packet.UDP
 
getSources() - Method in class org.onlab.packet.IGMPGroup
Return the list of source addresses.
getSpeakerFromPeer(IpAddress) - Method in class org.onosproject.routing.config.BgpConfig
Finds BGP speaker peering with a given external peer.
getSpeakerWithName(String) - Method in class org.onosproject.routing.config.BgpConfig
Examines whether a name of BGP speaker exists in configuration.
getSrc() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
Returns the source transponder port.
getSrc() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
Returns the source transponder port.
getSrc() - Method in class org.onosproject.net.intent.OpticalOduIntent
Returns the source transponder port.
getSsap() - Method in class org.onlab.packet.LLC
 
getState() - Method in class org.onlab.packet.lacp.LacpBaseTlv
Gets state.
getState() - Method in interface org.onosproject.upgrade.UpgradeService
Returns the current upgrade state.
getState(NodeId) - Method in interface org.onosproject.cluster.ClusterService
Returns the availability state of the specified controller node.
getState(NodeId) - Method in interface org.onosproject.cluster.ClusterStore
Returns the availability state of the specified controller node.
getState(ApplicationId) - Method in interface org.onosproject.app.ApplicationService
Return the application state.
getState(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
Returns the current application state.
getState(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
GetStatisticsCommand - Class in org.onosproject.cli.net
Fetches statistics.
GetStatisticsCommand() - Constructor for class org.onosproject.cli.net.GetStatisticsCommand
 
getStatisticsForPort(DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceService
Returns the port specific port statistics associated with the device and port.
getStatisticsForPort(DeviceId, PortNumber) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
getStatisticsForPort(DeviceId, PortNumber) - Method in interface org.onosproject.net.device.DeviceStore
Returns the port statistics of the specified device and port.
getStatTriggerFieldMap() - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
getStatTriggerFlag() - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
getStatus(DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfWatchdogService
Returns the last known pipeline status of the given device.
getStatValue(StatTriggerField) - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
getStorageDnsService() - Method in class org.onosproject.cluster.ClusterMetadata
Returns the DNS service through which to locate storage nodes.
getStorageNodes() - Method in class org.onosproject.cluster.ClusterMetadata
Returns the collection of storage nodes.
getStorageNodes() - Method in interface org.onosproject.cluster.ClusterStore
Returns the set of storage nodes.
getSubjectClasses() - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the set of subject classes for which configuration may be available.
getSubjectClasses() - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getSubjectFactory(Class) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the subject factory for the specified class.
getSubjectFactory(Class) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getSubjectFactory(String) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the subject factory with the specified key.
getSubjectFactory(String) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getSubjects(Class<S>) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the set of subjects for which some configuration is available.
getSubjects(Class<S>) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getSubjects(Class<S>) - Method in interface org.onosproject.net.config.NetworkConfigStore
Returns set of subjects of the specified class, which have some network configuration associated with them.
getSubjects(Class<S>, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigService
Returns the set of subjects for which the specified configuration is available.
getSubjects(Class<S>, Class<C>) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
getSubjects(Class<S>, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigStore
Returns set of subjects of the specified class, which have the specified class of network configuration associated with them.
getSubnetMask() - Method in class org.onlab.packet.RIPV2Entry
 
getSubOption(byte) - Method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
Gets sub-option from this option by given option code.
getSubtype() - Method in class org.onlab.packet.Slow
Gets subtype.
getSubType() - Method in class org.onlab.packet.LLDPOrganizationalTLV
Returns the value of the sub type.
getSystemMac() - Method in class org.onlab.packet.lacp.LacpBaseTlv
Gets system MAC address.
getSystemPriority() - Method in class org.onlab.packet.lacp.LacpBaseTlv
Gets system priority.
getT1() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Gets time 1.
getT1() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Gets time 1.
getT2() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Gets time 2.
getT2() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Gets time 2.
getTableStatistics() - Method in interface org.onosproject.net.behaviour.TableStatisticsDiscovery
Returns statistics for all match-action tables currently defined by the device forwarding pipeline.
getTableStatistics(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleStore
Returns the flow table statistics associated with a device.
getTag(short) - Method in class org.onlab.packet.PPPoED
Gets a tag from the packet.
getTaggedVlanId(ConnectPoint) - Method in interface org.onosproject.net.intf.InterfaceService
Returns tagged VLAN configured on given connect point.
getTagList(short) - Method in class org.onlab.packet.PPPoED
Gets a list of tags from the packet.
getTags() - Method in class org.onlab.packet.PPPoED
 
getTargetAddress() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Gets target address.
getTargetAddress() - Method in class org.onlab.packet.ndp.NeighborSolicitation
Gets target address.
getTargetAddress() - Method in class org.onlab.packet.ndp.Redirect
Gets target address.
getTargetHardwareAddress() - Method in class org.onlab.packet.ARP
 
getTargetPower(PortNumber, T) - Method in interface org.onosproject.net.behaviour.PowerConfig
Get the target power on the component.
getTargetPowerRange(PortNumber, T) - Method in interface org.onosproject.net.behaviour.PowerConfig
Get the acceptable target power range for setTargetPower, as optical components have different configurable output power ranges.
getTargetProtocolAddress() - Method in class org.onlab.packet.ARP
 
getTermFor(DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Returns the current master and number of past mastership hand-offs (terms) for a device.
getTimer() - Static method in class org.onlab.util.SharedExecutors
Returns the shared timer.
getTimers(MetricFilter) - Method in class org.onlab.metrics.MetricsManager
Fetches the existing Timers.
getTimers(MetricFilter) - Method in interface org.onlab.metrics.MetricsService
Fetches the existing Timers.
getTimestamp() - Method in class org.onlab.packet.ONOSLLDP
 
getTimestamp() - Method in interface org.onosproject.store.service.LogicalClockService
Generates a new logical timestamp.
getTimestamp(DeviceId) - Method in interface org.onosproject.net.device.DeviceClockService
Returns a new timestamp for the specified deviceId.
getTimestamp(IntentId) - Method in interface org.onosproject.net.intent.IntentClockService
Returns a new timestamp for the specified intent.
getTimestampTLV() - Method in class org.onlab.packet.ONOSLLDP
 
getTlv() - Method in class org.onlab.packet.lacp.Lacp
Gets LACP TLV.
getTopic(String, Serializer) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of Topic with specified name.
getTopic(String, Serializer) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of Topic with specified name.
getTopoHighlighterFactories() - Method in interface org.onosproject.ui.UiExtensionService
Returns the list of registered topo highlighter factories.
getToStringHelper() - Method in class org.onlab.packet.dhcp.Dhcp6Option
 
getTotal() - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
Get total memory of device.
getTotal() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns total intent count.
getTotalLength() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
getTotalLength() - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
getTotalLength() - Method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
 
getTotalLength() - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
getTotalLength() - Method in interface org.onlab.packet.EAPOLMkpduParameterSet
Total length; ie.
getTotalLength() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
 
getTotalLength() - Method in class org.onlab.packet.IPv4
 
getTotalLength() - Method in class org.onlab.packet.ipv6.Authentication
Gets the total length of this header.
getTrafficClass() - Method in class org.onlab.packet.IPv6
Gets traffic class.
getTrafficPeriod() - Static method in class org.onosproject.ui.topo.AbstractTopoMonitor
Returns the traffic refresh period in milliseconds.
getTransactionalMap(String, Serializer) - Method in interface org.onosproject.store.service.TransactionContext
Returns a transactional map data structure with the specified name.
getTransactionId() - Method in class org.onlab.packet.DHCP
 
getTransactionId() - Method in class org.onlab.packet.DHCP6
Gets the transaction ID of this DHCPv6 packet.
getTtl() - Method in class org.onlab.packet.IPv4
 
getTtl() - Method in class org.onlab.packet.LLDP
 
getTtl() - Method in class org.onlab.packet.MPLS
Returns the MPLS TTL of the packet.
getTtlBySeconds() - Method in class org.onlab.packet.ONOSLLDP
 
getType() - Method in class org.onlab.packet.bmp.Bmp
Returns message type.
getType() - Method in class org.onlab.packet.bmp.BmpPeer
Returns Peer Type.
getType() - Method in class org.onlab.packet.ipv6.BaseOptions
Gets the type of this option.
getType() - Method in class org.onlab.packet.LLDPTLV
 
getType() - Method in class org.onlab.packet.PPPoED
 
getType() - Method in class org.onlab.packet.PPPoEDTag
 
getType() - Method in class org.onlab.packet.RADIUSAttribute
Gets the attribute type.
getType() - Method in class org.onlab.packet.RIPV2AuthEntry
 
getType() - Method in class org.onosproject.cpman.ControlMetricsRequest
Obtains control metric type.
getType() - Method in class org.onosproject.cpman.ControlResourceRequest
Obtains control resource type.
getType() - Method in exception org.onosproject.net.behaviour.upf.UpfProgrammableException
Get the type of the exception.
getType() - Method in class org.onosproject.net.DataPlaneEntity
Returns the type of the entry.
getType() - Method in class org.onosproject.security.AppPermission
Returns type of permission.
getType(int) - Static method in enum org.onlab.packet.DHCP.MsgType
 
getType(int) - Static method in enum org.onlab.packet.DHCP6.MsgType
 
getType(int) - Static method in enum org.onlab.packet.RIP.CmdType
 
getType(int) - Static method in enum org.onlab.packet.RIPng.CmdType
 
getTypeByValue(int) - Static method in enum org.onlab.packet.PPPoED.Type
 
getUnit() - Method in class org.onosproject.cpman.ControlMetricsRequest
Obtains projected time unit.
getUnknownState() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns unknownState intent count.
getUntaggedVlanId(ConnectPoint) - Method in interface org.onosproject.net.intf.InterfaceService
Returns untagged VLAN configured on given connect point.
getUpdateTime(String) - Method in class org.onosproject.common.app.ApplicationArchive
Returns the timestamp in millis since start of epoch, of when the specified application was last modified or changed state.
getUpstreamAddr() - Method in class org.onlab.packet.pim.PIMJoinPrune
Get the upstreamAddr for this J/P request.
getUrgentPointer() - Method in class org.onlab.packet.TCP
Gets urgent pointer.
getUsed() - Method in class org.onosproject.net.behaviour.DeviceCpuStats
Get cpu usage of device.
getUsed() - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
Get used memory of device.
getUserNames() - Method in interface org.onosproject.ui.UiPreferencesService
Returns the list of user names that have user preferences available.
getUuid() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
getValidLifetime() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Gets valid lifetime.
getValidLifetime() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Gets valid lifetime.
getValue() - Method in enum org.onlab.packet.dhcp.Dhcp6Duid.DuidType
 
getValue() - Method in enum org.onlab.packet.DHCP.DHCPOptionCode
 
getValue() - Method in enum org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
getValue() - Method in enum org.onlab.packet.DHCP.MsgType
 
getValue() - Method in enum org.onlab.packet.DscpClass
Returns the short value of this DSCP class Enum.
getValue() - Method in enum org.onlab.packet.IPPrecedence
Returns the short value of this IP precedence Enum.
getValue() - Method in class org.onlab.packet.LLDPTLV
 
getValue() - Method in class org.onlab.packet.pim.PIMHelloOption
 
getValue() - Method in class org.onlab.packet.PPPoEDTag
 
getValue() - Method in class org.onlab.packet.RADIUSAttribute
Gets the attribute value.
getValue() - Method in enum org.onlab.packet.RIP.CmdType
 
getValue() - Method in enum org.onlab.packet.RIPng.CmdType
 
getValue() - Method in enum org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Gets the value as an integer.
getValue() - Method in enum org.onosproject.net.flow.criteria.Criterion.TcpFlags
Gets the value as an integer.
getValue(String) - Method in class org.onosproject.ui.lion.LionBundle
Returns the localized value for the given key, or null if no such mapping exists.
getVersion() - Method in class org.onlab.packet.bmp.Bmp
Returns message version.
getVersion() - Method in class org.onlab.packet.EAPOL
Gets the version.
getVersion() - Method in class org.onlab.packet.IP
Gets IP version number.
getVersion() - Method in class org.onlab.packet.IPv4
 
getVersion() - Method in class org.onlab.packet.IPv6
 
getVersion() - Method in class org.onlab.packet.PIM
Get the version of PIM.
getVersion() - Method in class org.onlab.packet.PPPoED
 
getVersion() - Method in class org.onlab.packet.RIP
 
getVersion() - Method in class org.onlab.packet.RIPng
 
getVersion() - Method in interface org.onosproject.upgrade.UpgradeService
Returns the currently active software version.
getVersion(NodeId) - Method in interface org.onosproject.cluster.ClusterService
Returns the version of the given controller node.
getVersion(NodeId) - Method in interface org.onosproject.cluster.ClusterStore
Returns the version of the specified controller node.
getVertexes() - Method in class org.onlab.graph.AdjacencyListsGraph
 
getVertexes() - Method in interface org.onlab.graph.Graph
Returns the set of vertexes comprising the graph.
getVertexes() - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
getViewExtension(String) - Method in interface org.onosproject.ui.UiExtensionService
Returns the user interface extension that contributed the specified view.
getVlanId() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Gets the vlan id of interface id.
getVlanID() - Method in class org.onlab.packet.Ethernet
Gets the VLAN ID.
getVlans() - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Provides the VLANs configured on a device.
getVni() - Method in class org.onlab.packet.VXLAN
Returns VNI(VXLAN Network Identifier).
getWBit() - Method in class org.onlab.packet.pim.PIMAddrSource
Return the wBit, used in Join/Prune messages.
getWindowCount() - Method in class org.onlab.util.SlidingWindowCounter
Gets the total count for all slots.
getWindowCount(int) - Method in class org.onlab.util.SlidingWindowCounter
Gets the total count for the last N window slots.
getWindowRate() - Method in class org.onlab.util.SlidingWindowCounter
Returns the average rate over the window.
getWindowRate(int) - Method in class org.onlab.util.SlidingWindowCounter
Returns the average rate over the given window.
getWindowSize() - Method in class org.onlab.packet.TCP
Gets TCP window size.
getWithdrawing() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Withdrawing intent count.
getWithdrawn() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns Withdrawn intent count.
getWithdrawReq() - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Returns WithdrawReq intent count.
getWithMessage() - Method in class org.onlab.junit.ExceptionTest
 
getWithMessageAndCause() - Method in class org.onlab.junit.ExceptionTest
 
getWorkQueue(String, Serializer) - Method in interface org.onosproject.store.service.PrimitiveService
Returns an instance of WorkQueue with specified name.
getWorkQueue(String, Serializer) - Method in interface org.onosproject.store.service.StorageService
Returns an instance of WorkQueue with specified name.
getWorkQueueNames() - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Returns the names of all created WorkQueue instances.
getYourIPAddress() - Method in class org.onlab.packet.DHCP
 
getZBit() - Method in class org.onlab.packet.pim.PIMAddrGroup
Return the z bit for admin scoping.
GIGA - org.onosproject.ui.topo.TopoUtils.Magnitude
 
GIS_PERSISTENCE_ENABLED - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
GIS_PERSISTENCE_ENABLED_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
givenGroupId() - Method in class org.onosproject.net.group.DefaultGroupDescription
Returns groupId passed in by application.
givenGroupId() - Method in interface org.onosproject.net.group.GroupDescription
Returns groupId passed in by caller.
globalScope() - Static method in class org.onosproject.net.meter.MeterScope
Create a global Meter Scope.
glyph(String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns a glyph badge, with default status.
glyph(NodeBadge.Status, String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns a glyph badge, with the given status.
glyph(NodeBadge.Status, String, String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns a glyph badge, with the given status and optional message.
GLYPH_READ - org.onosproject.security.AppPermission.Type
 
GLYPH_WRITE - org.onosproject.security.AppPermission.Type
 
GlyphConstants - Class in org.onosproject.ui
Defines constants for standard glyph identifiers.
glyphId() - Method in class org.onosproject.ui.topo.PropertyPanel
Returns the glyph identifier.
glyphId(String) - Method in class org.onosproject.ui.topo.PropertyPanel
Sets the glyph identifier.
glyphs() - Method in interface org.onosproject.ui.UiGlyphFactory
Produces a list of glyphns to be added to the topology view.
GM_POLL_FREQUENCY - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
GM_POLL_FREQUENCY_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
GM_PURGE_ON_DISCONNECTION - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
GM_PURGE_ON_DISCONNECTION_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
Graph<V extends Vertex,​E extends Edge> - Interface in org.onlab.graph
Abstraction of a directed graph structure.
GraphDescription - Interface in org.onosproject.net.topology
Describes attribute(s) of a network graph.
GraphPathSearch<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Representation of a graph path search algorithm.
GraphPathSearch.Result<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Abstraction of a path search result.
GraphSearch<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Representation of a graph search algorithm and its outcome.
GraphSearch.Result<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Notion of a graph search result.
GRE - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a L3 tunnel.
greenAction() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the action to be taken for traffic marked as green.
greenAction(BandwidthProfileAction) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the green action of this builder.
GRID - org.onosproject.ui.topo.LayoutLocation.Type
 
GRID_X - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for grid-X (e.g.
GRID_X - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for grid X coordinate.
GRID_X - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
GRID_Y - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for grid-Y (e.g.
GRID_Y - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for grid Y coordinate.
GRID_Y - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
gridCoordsSet() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns true if the grid coordinates (gridY and gridX) are set on this element, i.e.
gridType() - Method in class org.onosproject.net.OchSignal
Returns grid type.
GridType - Enum in org.onosproject.net
Represents type of wavelength grid.
gridX() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns element grid x-coordinate.
gridX(Double) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the element grid x-coordinate.
gridY() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns element grid y-coordinate.
gridY(Double) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the element grid y-coordinate.
group() - Method in class org.onosproject.net.mcast.McastRoute
Deprecated.
Fetches the group address of this route.
group() - Method in class org.onosproject.routing.NextHop
Returns the next hop group.
group(GroupId) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
group(GroupId) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the group ID.
Group - Interface in org.onosproject.net.group
ONOS representation of group that is stored in the system.
GROUP - org.onosproject.net.DataPlaneEntity.Type
Group entity.
GROUP - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that traffic should be sent out of a group.
GROUP_ADD_FAILED - org.onosproject.net.group.GroupEvent.Type
Signifies that a request to create Group has failed.
GROUP_ADD_REQUESTED - org.onosproject.net.group.GroupEvent.Type
 
GROUP_ADDED - org.onosproject.net.group.GroupEvent.Type
Signifies that a new Group has been detected.
GROUP_BUCKET_FAILOVER - org.onosproject.net.group.GroupEvent.Type
Signifies change in the first live bucket in failover group (i.e.
GROUP_CAPABLE - Static variable in interface org.onosproject.net.group.GroupProvider
Group capable property name.
GROUP_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
GROUP_DELETE - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
GROUP_EVENT - org.onosproject.security.AppPermission.Type
 
GROUP_EXISTS - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
GROUP_READ - org.onosproject.security.AppPermission.Type
 
GROUP_REMOVE_FAILED - org.onosproject.net.group.GroupEvent.Type
Signifies that a request to remove Group has failed.
GROUP_REMOVE_REQUESTED - org.onosproject.net.group.GroupEvent.Type
 
GROUP_REMOVED - org.onosproject.net.group.GroupEvent.Type
Signifies that a Group has been removed.
GROUP_TABLE - Static variable in class org.onosproject.ui.GlyphConstants
 
GROUP_UPDATE_FAILED - org.onosproject.net.group.GroupEvent.Type
Signifies that a request to update Group has failed.
GROUP_UPDATE_REQUESTED - org.onosproject.net.group.GroupEvent.Type
 
GROUP_UPDATED - org.onosproject.net.group.GroupEvent.Type
Signifies that a Group has been updated.
GROUP_WRITE - org.onosproject.security.AppPermission.Type
 
Group.GroupState - Enum in org.onosproject.net.group
State of the group object in ONOS.
GroupBucket - Interface in org.onosproject.net.group
Group Bucket definition.
GroupBuckets - Class in org.onosproject.net.group
Immutable collection of group bucket.
GroupBuckets(List<GroupBucket>) - Constructor for class org.onosproject.net.group.GroupBuckets
Creates a immutable list of group bucket.
groupById(GroupId) - Method in class org.onosproject.net.PipelineTraceableInput
Returns the group associated with the given group id.
GroupDescription - Interface in org.onosproject.net.group
ONOS representation of group description that is used to create a group.
GroupDescription.Type - Enum in org.onosproject.net.group
Types of the group supported by ONOS.
groupedThreadFactory(String) - Static method in class org.onlab.util.GroupedThreadFactory
Returns thread factory for producing threads associated with the specified group name.
GroupedThreadFactory - Class in org.onlab.util
Thread factory for creating threads that belong to the specified thread group.
groupedThreads(String, String) - Static method in class org.onlab.util.Tools
Returns a thread factory that produces threads named according to the supplied name pattern and from the specified thread-group.
groupedThreads(String, String, Logger) - Static method in class org.onlab.util.Tools
Returns a thread factory that produces threads named according to the supplied name pattern and from the specified thread-group.
GroupEvent - Class in org.onosproject.net.group
Describes group events.
GroupEvent(GroupEvent.Type, Group) - Constructor for class org.onosproject.net.group.GroupEvent
Creates an event of a given type and for the specified Group and the current time.
GroupEvent(GroupEvent.Type, Group, long) - Constructor for class org.onosproject.net.group.GroupEvent
Creates an event of a given type and for the specified Group and time.
GroupEvent.Type - Enum in org.onosproject.net.group
Type of flow rule events.
GROUPEXISTS - org.onosproject.net.flowobjective.ObjectiveError
Group already exists.
groupId() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
groupId() - Method in interface org.onosproject.net.flow.FlowRule
Returns the group id of this flow.
groupId() - Method in class org.onosproject.net.flow.instructions.Instructions.GroupInstruction
 
groupId() - Method in class org.onosproject.net.group.GroupOperation
Returns group identifier attribute of the operation.
groupId() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
Returns the group ID of this handle.
groupId() - Method in class org.onosproject.net.pi.runtime.PiGroupKey
Returns the group ID defined by this key.
groupId() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
Returns the identifier of this multicast group, unique in the scope of a PRE instance.
groupId() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
Returns the multicast group ID associated with this handle.
GroupId - Class in org.onosproject.core
Group identifier.
GroupId(int) - Constructor for class org.onosproject.core.GroupId
 
GROUPINSTALLATIONFAILED - org.onosproject.net.flowobjective.ObjectiveError
The group installation for this objective failed.
GroupKey - Interface in org.onosproject.net.group
Representation of generalized Key that would be used to store groups in < Key, Value > store.
GroupListener - Interface in org.onosproject.net.group
Entity capable of receiving Group related events.
GROUPMISSING - org.onosproject.net.flowobjective.ObjectiveError
The group was reported as installed but is missing.
GroupOperation - Class in org.onosproject.net.group
Group operation definition to be used between core and provider layers of group subsystem.
GroupOperation.GroupMsgErrorCode - Enum in org.onosproject.net.group
Possible error codes for a failure of a group operation.
GroupOperation.Type - Enum in org.onosproject.net.group
 
groupOperationFailed(DeviceId, GroupOperation) - Method in interface org.onosproject.net.group.GroupProviderService
Notifies core if any failure from data plane during group operations.
groupOperationFailed(DeviceId, GroupOperation) - Method in interface org.onosproject.net.group.GroupStore
Indicates the group operations failed.
GroupOperations - Class in org.onosproject.net.group
Immutable collection of group operation to be used between core and provider layers of group subsystem.
GroupOperations(List<GroupOperation>) - Constructor for class org.onosproject.net.group.GroupOperations
Creates a immutable list of group operation.
GroupProgrammable - Interface in org.onosproject.net.group
Group programmable device behaviour.
GroupProvider - Interface in org.onosproject.net.group
Abstraction of group provider.
GroupProviderRegistry - Interface in org.onosproject.net.group
Abstraction for a group provider registry.
GroupProviderService - Interface in org.onosproject.net.group
Service through which Group providers can inject information into the core.
GROUPREMOVALFAILED - org.onosproject.net.flowobjective.ObjectiveError
The group removal for this objective failed.
groups() - Method in class org.onosproject.net.PipelineTraceableInput
Getter for the groups.
GroupService - Interface in org.onosproject.net.group
Service for create/update/delete "group" in the devices.
GroupsListCommand - Class in org.onosproject.cli.net
Lists all groups in the system.
GroupsListCommand() - Constructor for class org.onosproject.cli.net.GroupsListCommand
 
GroupStatusCompleter - Class in org.onosproject.cli.net
Group status completer.
GroupStatusCompleter() - Constructor for class org.onosproject.cli.net.GroupStatusCompleter
 
GroupStore - Interface in org.onosproject.net.group
Manages inventory of groups per device; not intended for direct use.
GroupStore.UpdateType - Enum in org.onosproject.net.group
 
GroupStoreDelegate - Interface in org.onosproject.net.group
Group store delegate abstraction.
groupTranslator() - Method in interface org.onosproject.net.pi.service.PiTranslationService
Returns a group translator.
groupType() - Method in class org.onosproject.net.group.GroupOperation
Returns group type attribute of the operation.
GroupTypeCompleter - Class in org.onosproject.cli.net
Group status completer.
GroupTypeCompleter() - Constructor for class org.onosproject.cli.net.GroupTypeCompleter
 
GtpTunnel - Class in org.onosproject.net.behaviour.upf
A structure representing a unidirectional GTP tunnel.
GtpTunnel.GtpTunnelBuilder - Class in org.onosproject.net.behaviour.upf
 
GtpTunnelBuilder() - Constructor for class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
 
GuavaCollectors - Class in org.onlab.util
Implementations of Collector that implement various useful reduction operations, such as accumulating elements into Guava collections.

H

handle() - Method in class org.onosproject.net.pi.service.PiTranslatedEntity
Returns the PI entity handle.
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in class org.onlab.util.BlockingAwareFuture
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiCounterCell
 
handle(DeviceId) - Method in interface org.onosproject.net.pi.runtime.PiEntity
Returns a handle for this PI entity and the given device ID.
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
 
handle(DeviceId) - Method in class org.onosproject.net.pi.runtime.PiTableEntry
 
handle(ClusterMessage) - Method in interface org.onosproject.store.cluster.messaging.ClusterMessageHandler
Deprecated.
Handles/Processes the cluster message.
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in class org.onlab.util.BlockingAwareFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
handleMessage(NeighbourMessageContext, HostService) - Method in class org.onosproject.net.neighbour.DefaultNeighbourMessageHandler
 
handleMessage(NeighbourMessageContext, HostService) - Method in interface org.onosproject.net.neighbour.NeighbourMessageHandler
Handles a neighbour message.
handler() - Method in class org.onosproject.net.driver.AbstractHandlerBehaviour
 
handler() - Method in interface org.onosproject.net.driver.HandlerBehaviour
Returns the driver handler context on which this behaviour operates.
handler() - Method in interface org.onosproject.net.neighbour.NeighbourHandlerRegistration
Gets the neighbour message handler.
HandlerBehaviour - Interface in org.onosproject.net.driver
Representation of a facet of behaviour that can be used to interact with an entity (in context of DriverHandler).
HARD_TIMEOUT - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
hardTimeout() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
hardTimeout() - Method in interface org.onosproject.net.flow.FlowRule
Returns the hard timeout for this flow requested by an application.
hardwareAddressLength - Variable in class org.onlab.packet.ARP
 
hardwareAddressLength - Variable in class org.onlab.packet.DHCP
 
hardwareType - Variable in class org.onlab.packet.ARP
 
hardwareType - Variable in class org.onlab.packet.DHCP
 
hasActionParameters() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Instances created as a result of DELETE write requests will not have action parameters, only match keys.
hasBackup() - Method in class org.onlab.graph.DisjointPathPair
Checks if this path pair contains a backup/secondary path.
hasBehaviour(Class<? extends Behaviour>) - Method in class org.onosproject.net.driver.DefaultDriver
 
hasBehaviour(Class<? extends Behaviour>) - Method in interface org.onosproject.net.driver.Driver
Indicates whether or not the driver, or any of its parents, support the specified class of behaviour.
hasBehaviour(Class<? extends Behaviour>) - Method in interface org.onosproject.net.driver.DriverHandler
Indicates whether or not the driver, or any of its parents, support the specified class of behaviour.
hasBehaviour(Class<? extends Behaviour>) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
 
hasBehaviour(Class<? extends Behaviour>) - Method in interface org.onosproject.net.pi.model.PiPipeconf
Indicates whether or not the pipeconf supports the specified class of behaviour.
hasBitWidth() - Method in interface org.onosproject.net.pi.model.PiActionParamModel
Return true is the action parameters has a predefined bit width.
hasBitWidth() - Method in interface org.onosproject.net.pi.model.PiMatchFieldModel
Return true is the match field has a predefined bit width.
hasBitWidth() - Method in interface org.onosproject.net.pi.model.PiPacketMetadataModel
Return true is the packet metadata has a fixed bit width.
hasBurst(boolean) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
hasBurst(boolean) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the burst capabilities.
hasChanged() - Method in class org.onosproject.cluster.PartitionDiff
Returns if there are differences between the two values.
hasChildren() - Method in interface org.onosproject.store.service.DocumentTreeNode
Returns if this node has one or more children.
hasConnection() - Method in interface org.onosproject.net.driver.DeviceConnect
Returns true if a connection to the device exists, false otherwise.
hasDelegate() - Method in class org.onosproject.store.AbstractStore
 
hasDelegate() - Method in interface org.onosproject.store.Store
Indicates whether the store has a delegate.
hasField(ObjectNode, String) - Method in class org.onosproject.net.config.Config
Returns true if the given node contains a field with the given name.
hasField(String) - Method in class org.onosproject.net.config.Config
Returns true if this config contains a field with the given name.
hasFields(ObjectNode, String...) - Method in class org.onosproject.net.config.Config
Indicates whether all specified fields are present in a particular JSON object.
hasFields(String...) - Method in class org.onosproject.net.config.Config
Indicates whether all specified fields are present in the backing JSON.
hash() - Method in class org.onosproject.net.intent.Key
 
HASH_FUNNEL - Static variable in class org.onosproject.cluster.ClusterMetadata
 
hashCode() - Method in class org.onlab.graph.AbstractEdge
 
hashCode() - Method in class org.onlab.graph.AdjacencyListsGraph
 
hashCode() - Method in class org.onlab.graph.DefaultMutablePath
 
hashCode() - Method in class org.onlab.graph.DefaultPath
 
hashCode() - Method in class org.onlab.graph.DisjointPathPair
 
hashCode() - Method in class org.onlab.graph.Heap
 
hashCode() - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
hashCode() - Method in class org.onlab.graph.ScalarWeight
 
hashCode() - Method in class org.onlab.packet.ARP
 
hashCode() - Method in class org.onlab.packet.BasePacket
 
hashCode() - Method in class org.onlab.packet.bmp.Bmp
 
hashCode() - Method in class org.onlab.packet.bmp.BmpPeer
 
hashCode() - Method in class org.onlab.packet.ChassisId
 
hashCode() - Method in class org.onlab.packet.Data
 
hashCode() - Method in class org.onlab.packet.dhcp.CircuitId
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
hashCode() - Method in class org.onlab.packet.dhcp.Dhcp6Option
 
hashCode() - Method in class org.onlab.packet.dhcp.DhcpOption
 
hashCode() - Method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
 
hashCode() - Method in class org.onlab.packet.EAP
 
hashCode() - Method in class org.onlab.packet.EAPOL
 
hashCode() - Method in class org.onlab.packet.Ethernet
 
hashCode() - Method in class org.onlab.packet.EthType
 
hashCode() - Method in class org.onlab.packet.ICMP
 
hashCode() - Method in class org.onlab.packet.ICMP6
 
hashCode() - Method in class org.onlab.packet.ICMPEcho
 
hashCode() - Method in class org.onlab.packet.IGMP
 
hashCode() - Method in class org.onlab.packet.IGMPMembership
 
hashCode() - Method in class org.onlab.packet.IGMPQuery
 
hashCode() - Method in class org.onlab.packet.IpAddress
 
hashCode() - Method in class org.onlab.packet.IpPrefix
 
hashCode() - Method in class org.onlab.packet.IPv4
 
hashCode() - Method in class org.onlab.packet.ipv6.Authentication
 
hashCode() - Method in class org.onlab.packet.ipv6.BaseOptions
 
hashCode() - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
 
hashCode() - Method in class org.onlab.packet.ipv6.Fragment
 
hashCode() - Method in class org.onlab.packet.IPv6
 
hashCode() - Method in class org.onlab.packet.ipv6.Routing
 
hashCode() - Method in class org.onlab.packet.lacp.Lacp
 
hashCode() - Method in class org.onlab.packet.lacp.LacpBaseTlv
 
hashCode() - Method in class org.onlab.packet.lacp.LacpCollectorTlv
 
hashCode() - Method in class org.onlab.packet.lacp.LacpState
 
hashCode() - Method in class org.onlab.packet.LLDP
 
hashCode() - Method in class org.onlab.packet.LLDPOrganizationalTLV
 
hashCode() - Method in class org.onlab.packet.LLDPTLV
 
hashCode() - Method in class org.onlab.packet.MacAddress
 
hashCode() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
 
hashCode() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
hashCode() - Method in class org.onlab.packet.ndp.NeighborSolicitation
 
hashCode() - Method in class org.onlab.packet.ndp.Redirect
 
hashCode() - Method in class org.onlab.packet.ndp.RouterAdvertisement
 
hashCode() - Method in class org.onlab.packet.ndp.RouterSolicitation
 
hashCode() - Method in class org.onlab.packet.PIM
 
hashCode() - Method in class org.onlab.packet.pim.PIMAddrGroup
 
hashCode() - Method in class org.onlab.packet.pim.PIMAddrSource
 
hashCode() - Method in class org.onlab.packet.pim.PIMAddrUnicast
 
hashCode() - Method in class org.onlab.packet.RIP
 
hashCode() - Method in class org.onlab.packet.RIPng
 
hashCode() - Method in class org.onlab.packet.RIPngEntry
 
hashCode() - Method in class org.onlab.packet.RIPV2AuthEntry
 
hashCode() - Method in class org.onlab.packet.RIPV2Entry
 
hashCode() - Method in class org.onlab.packet.Slow
 
hashCode() - Method in class org.onlab.packet.TCP
 
hashCode() - Method in class org.onlab.packet.TpPort
 
hashCode() - Method in class org.onlab.packet.UDP
 
hashCode() - Method in class org.onlab.packet.VXLAN
 
hashCode() - Method in class org.onlab.util.ClosedOpenRange
 
hashCode() - Method in class org.onlab.util.Counter
 
hashCode() - Method in class org.onlab.util.Frequency
 
hashCode() - Method in class org.onlab.util.Identifier
Returns the hashcode of the identifier.
hashCode() - Method in class org.onlab.util.ImmutableByteSequence
 
hashCode() - Method in class org.onlab.util.Match
 
hashCode() - Method in class org.onlab.util.UnmodifiableDeque
 
hashCode() - Method in class org.onosproject.alarm.DefaultAlarm
 
hashCode() - Method in class org.onosproject.cfg.ConfigProperty
 
hashCode() - Method in class org.onosproject.cluster.ClusterEvent
 
hashCode() - Method in class org.onosproject.cluster.ClusterMetadata
 
hashCode() - Method in class org.onosproject.cluster.ClusterMetadataEvent
 
hashCode() - Method in class org.onosproject.cluster.DefaultControllerNode
 
hashCode() - Method in class org.onosproject.cluster.DefaultPartition
 
hashCode() - Method in class org.onosproject.cluster.Leader
 
hashCode() - Method in class org.onosproject.cluster.Leadership
 
hashCode() - Method in class org.onosproject.cluster.LeadershipEvent
 
hashCode() - Method in class org.onosproject.cluster.Member
 
hashCode() - Method in class org.onosproject.cluster.PartitionDiff
 
hashCode() - Method in class org.onosproject.cluster.RoleInfo
 
hashCode() - Method in class org.onosproject.core.DefaultApplication
 
hashCode() - Method in class org.onosproject.core.DefaultApplicationId
 
hashCode() - Method in class org.onosproject.core.Version
 
hashCode() - Method in class org.onosproject.cpman.ControlLoadSnapshot
 
hashCode() - Method in class org.onosproject.cpman.ControlMetricsRequest
 
hashCode() - Method in class org.onosproject.cpman.ControlResourceRequest
 
hashCode() - Method in class org.onosproject.cpman.DefaultControlMessage
 
hashCode() - Method in class org.onosproject.cpman.MetricValue
 
hashCode() - Method in class org.onosproject.event.Change
 
hashCode() - Method in class org.onosproject.mastership.MastershipEvent
 
hashCode() - Method in class org.onosproject.mastership.MastershipInfo
 
hashCode() - Method in class org.onosproject.mastership.MastershipTerm
 
hashCode() - Method in class org.onosproject.net.AbstractDescription
 
hashCode() - Method in class org.onosproject.net.behaviour.BandwidthProfile
 
hashCode() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
 
hashCode() - Method in class org.onosproject.net.behaviour.BridgeName
 
hashCode() - Method in class org.onosproject.net.behaviour.ControllerInfo
 
hashCode() - Method in class org.onosproject.net.behaviour.DefaultPatchDescription
 
hashCode() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
hashCode() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
hashCode() - Method in class org.onosproject.net.behaviour.DeviceCpuStats
 
hashCode() - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
 
hashCode() - Method in class org.onosproject.net.behaviour.DeviceSystemStats
 
hashCode() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
 
hashCode() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective
 
hashCode() - Method in class org.onosproject.net.behaviour.MirroringName
 
hashCode() - Method in class org.onosproject.net.behaviour.MirroringStatistics
 
hashCode() - Method in class org.onosproject.net.behaviour.QosId
 
hashCode() - Method in class org.onosproject.net.behaviour.QueueId
 
hashCode() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
hashCode() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
hashCode() - Method in class org.onosproject.net.behaviour.trafficcontrol.PolicingResource
 
hashCode() - Method in class org.onosproject.net.behaviour.TunnelEndPoint
 
hashCode() - Method in class org.onosproject.net.behaviour.TunnelKey
 
hashCode() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
 
hashCode() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
 
hashCode() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
 
hashCode() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
 
hashCode() - Method in class org.onosproject.net.ConnectPoint
 
hashCode() - Method in class org.onosproject.net.DataPlaneEntity
 
hashCode() - Method in class org.onosproject.net.DefaultAnnotations
 
hashCode() - Method in class org.onosproject.net.DefaultDevice
 
hashCode() - Method in class org.onosproject.net.DefaultDisjointPath
 
hashCode() - Method in class org.onosproject.net.DefaultHost
 
hashCode() - Method in class org.onosproject.net.DefaultLink
 
hashCode() - Method in class org.onosproject.net.DefaultPath
 
hashCode() - Method in class org.onosproject.net.DefaultPort
 
hashCode() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
hashCode() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
 
hashCode() - Method in class org.onosproject.net.device.DefaultPortDescription
 
hashCode() - Method in class org.onosproject.net.DeviceId
 
hashCode() - Method in class org.onosproject.net.driver.DefaultDriver
 
hashCode() - Method in class org.onosproject.net.FilteredConnectPoint
 
hashCode() - Method in class org.onosproject.net.flow.BatchOperation
 
hashCode() - Method in class org.onosproject.net.flow.BatchOperationEntry
 
hashCode() - Method in class org.onosproject.net.flow.criteria.ArpHaCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.ArpOpCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.ArpPaCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.EthCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.EthTypeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.ExtensionCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.ExtensionSelectorType
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IcmpCodeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IcmpTypeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.Icmpv6CodeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.Icmpv6TypeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPDscpCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPEcnCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPProtocolCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPv6ExthdrFlagsCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPv6FlowLabelCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPv6NDLinkLayerAddressCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.IPv6NDTargetAddressCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.LambdaCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.MetadataCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.MplsBosCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.MplsCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.MplsTcCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.OchSignalCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.OchSignalTypeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.OduSignalIdCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.OduSignalTypeCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.PbbIsidCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.PiCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.PortCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.SctpPortCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.TcpFlagsCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.TcpPortCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.TunnelIdCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.UdpPortCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
 
hashCode() - Method in class org.onosproject.net.flow.criteria.VlanIdCriterion
 
hashCode() - Method in class org.onosproject.net.flow.criteria.VlanPcpCriterion
 
hashCode() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
hashCode() - Method in class org.onosproject.net.flow.DefaultTrafficSelector
 
hashCode() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
hashCode() - Method in class org.onosproject.net.flow.instructions.ExtensionTreatmentType
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.ExtensionInstructionWrapper
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.GroupInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.MetadataInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.MeterInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.NoActionInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.OutputInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.SetQueueInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.TableTypeTransition
 
hashCode() - Method in class org.onosproject.net.flow.instructions.Instructions.TruncateInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction.ModOchSignalInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction.ModOduSignalIdInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModEtherInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsBosInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsHeaderInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsLabelInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsTtlInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModTunnelIdInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanHeaderInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanIdInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanPcpInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpEthInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpIPInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpOpInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModDscpInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPv6FlowLabelInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModTtlInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction.ModTransportPortInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.PiInstruction
 
hashCode() - Method in class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
 
hashCode() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
hashCode() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
hashCode() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
hashCode() - Method in class org.onosproject.net.flowobjective.DefaultNextTreatment
 
hashCode() - Method in class org.onosproject.net.flowobjective.FilteringObjQueueKey
 
hashCode() - Method in class org.onosproject.net.flowobjective.ForwardingObjQueueKey
 
hashCode() - Method in class org.onosproject.net.flowobjective.IdNextTreatment
 
hashCode() - Method in class org.onosproject.net.flowobjective.NextObjQueueKey
 
hashCode() - Method in class org.onosproject.net.group.DefaultGroup
 
hashCode() - Method in class org.onosproject.net.group.DefaultGroupBucket
 
hashCode() - Method in class org.onosproject.net.group.DefaultGroupDescription
 
hashCode() - Method in class org.onosproject.net.group.DefaultGroupKey
 
hashCode() - Method in class org.onosproject.net.group.GroupBuckets
 
hashCode() - Method in class org.onosproject.net.group.GroupOperation
 
hashCode() - Method in class org.onosproject.net.host.DefaultHostDescription
 
hashCode() - Method in class org.onosproject.net.host.InterfaceIpAddress
 
hashCode() - Method in class org.onosproject.net.HostId
 
hashCode() - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.BandwidthConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.EncapsulationConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.LatencyConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.LinkTypeConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.MarkerConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.MeteredConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.ObstacleConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.TierConstraint
 
hashCode() - Method in class org.onosproject.net.intent.constraint.WaypointConstraint
 
hashCode() - Method in class org.onosproject.net.intent.Intent
 
hashCode() - Method in class org.onosproject.net.intent.IntentData
 
hashCode() - Method in class org.onosproject.net.intent.IntentOperation
 
hashCode() - Method in class org.onosproject.net.intent.IntentOperationContext
 
hashCode() - Method in class org.onosproject.net.intent.Key
 
hashCode() - Method in class org.onosproject.net.intf.Interface
 
hashCode() - Method in class org.onosproject.net.IpElementId
 
hashCode() - Method in class org.onosproject.net.link.DefaultLinkDescription
 
hashCode() - Method in class org.onosproject.net.LinkKey
 
hashCode() - Method in class org.onosproject.net.MarkerResource
 
hashCode() - Method in class org.onosproject.net.mcast.McastEvent
Deprecated.
 
hashCode() - Method in class org.onosproject.net.mcast.McastRoute
Deprecated.
 
hashCode() - Method in class org.onosproject.net.meter.DefaultMeter
 
hashCode() - Method in class org.onosproject.net.meter.MeterFeaturesKey
Deprecated.
 
hashCode() - Method in class org.onosproject.net.meter.MeterKey
 
hashCode() - Method in class org.onosproject.net.meter.MeterOperation
 
hashCode() - Method in class org.onosproject.net.meter.MeterTableKey
 
hashCode() - Method in class org.onosproject.net.NshContextHeader
 
hashCode() - Method in class org.onosproject.net.NshServiceIndex
 
hashCode() - Method in class org.onosproject.net.OchSignal
 
hashCode() - Method in class org.onosproject.net.OduSignalId
 
hashCode() - Method in class org.onosproject.net.packet.DefaultInboundPacket
 
hashCode() - Method in class org.onosproject.net.packet.DefaultOutboundPacket
 
hashCode() - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
hashCode() - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiBitString
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiBool
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiEnumString
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiErrorString
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiHeader
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderStack
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnionStack
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiStruct
 
hashCode() - Method in class org.onosproject.net.pi.runtime.data.PiTuple
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiAction
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionParam
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionSet
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiActionSet.WeightedAction
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiCounterCell
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiCounterCellData
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiExactFieldMatch
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiGroupKey
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiLpmFieldMatch
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMatchKey
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMeterBand
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiOptionalFieldMatch
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiPacketOperation
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiPreReplica
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiRangeFieldMatch
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiRegisterCellId
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
 
hashCode() - Method in class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
 
hashCode() - Method in class org.onosproject.net.PipelineTraceableHitChain
 
hashCode() - Method in class org.onosproject.net.PipelineTraceablePacket
 
hashCode() - Method in class org.onosproject.net.PortNumber
 
hashCode() - Method in class org.onosproject.net.provider.ProviderId
 
hashCode() - Method in class org.onosproject.net.region.DefaultRegion
 
hashCode() - Method in class org.onosproject.net.resource.ContinuousResource
 
hashCode() - Method in class org.onosproject.net.resource.ContinuousResourceId
 
hashCode() - Method in class org.onosproject.net.resource.DiscreteResource
 
hashCode() - Method in class org.onosproject.net.resource.DiscreteResourceId
 
hashCode() - Method in class org.onosproject.net.resource.ResourceAllocation
 
hashCode() - Method in class org.onosproject.net.resource.ResourceConsumerId
 
hashCode() - Method in class org.onosproject.net.ResourceGroup
 
hashCode() - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
hashCode() - Method in class org.onosproject.net.topology.DefaultTopologyEdge
 
hashCode() - Method in class org.onosproject.net.topology.DefaultTopologyVertex
 
hashCode() - Method in class org.onosproject.net.TributarySlot
 
hashCode() - Method in class org.onosproject.net.utils.ForwardingPort
 
hashCode() - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
 
hashCode() - Method in class org.onosproject.routing.NextHop
 
hashCode() - Method in class org.onosproject.routing.NextHopGroupKey
 
hashCode() - Method in class org.onosproject.security.Permission
 
hashCode() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
 
hashCode() - Method in class org.onosproject.store.cluster.messaging.Endpoint
 
hashCode() - Method in class org.onosproject.store.cluster.messaging.MessageSubject
 
hashCode() - Method in class org.onosproject.store.flow.ReplicaInfo
 
hashCode() - Method in class org.onosproject.store.LogicalTimestamp
 
hashCode() - Method in class org.onosproject.store.primitives.MapUpdate
 
hashCode() - Method in class org.onosproject.store.primitives.NodeUpdate
 
hashCode() - Method in class org.onosproject.store.primitives.PartitionEvent
 
hashCode() - Method in class org.onosproject.store.service.AtomicValueEvent
 
hashCode() - Method in class org.onosproject.store.service.DocumentPath
 
hashCode() - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
 
hashCode() - Method in class org.onosproject.store.service.MapEvent
 
hashCode() - Method in class org.onosproject.store.service.MultimapEvent
 
hashCode() - Method in class org.onosproject.store.service.MultiValuedTimestamp
 
hashCode() - Method in class org.onosproject.store.service.SetEvent
 
hashCode() - Method in class org.onosproject.store.service.TransactionLog
 
hashCode() - Method in class org.onosproject.store.service.Version
 
hashCode() - Method in class org.onosproject.store.service.Versioned
 
hashCode() - Method in class org.onosproject.store.service.WallClockTimestamp
 
hashCode() - Method in interface org.onosproject.store.Timestamp
 
hashCode() - Method in class org.onosproject.ui.lion.LionBundle.LionItem
 
hashCode() - Method in class org.onosproject.ui.model.topo.UiLinkId
 
hashCode() - Method in class org.onosproject.ui.topo.Mod
 
hashCode() - Method in class org.onosproject.ui.topo.PropertyPanel.Prop
 
hashCode() - Method in class org.onosproject.ui.UiSessionToken
 
hashCode() - Method in class org.onosproject.ui.UiView
 
hashCode() - Method in class org.onosproject.upgrade.UpgradeEvent
 
hashCodeExtended() - Method in class org.onosproject.net.PortNumber
 
HASHED - org.onosproject.net.flowobjective.NextObjective.Type
A hashed packet processing.
HashedPathSelectionConstraint - Class in org.onosproject.net.intent.constraint
A constraint for intent.hashCode() based path selection.
HashedPathSelectionConstraint() - Constructor for class org.onosproject.net.intent.constraint.HashedPathSelectionConstraint
 
hasMaxSize() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
hasMaxSize() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
To check whether maxSize is present in this TableStatisticsEntry.
hasMoreElements() - Method in class org.onosproject.rest.AbstractInjectionResource.StreamEnumeration
 
hasName() - Method in class org.onosproject.net.PortNumber
Indicates whether this port number was created with a port name, or only with a number.
hasNext() - Method in interface org.onosproject.store.service.AsyncIterator
Returns whether the iterator has a next item.
hasOnlyFields(ObjectNode, String...) - Method in class org.onosproject.net.config.Config
Indicates whether only the specified fields are present in a particular JSON object.
hasOnlyFields(String...) - Method in class org.onosproject.net.config.Config
Indicates whether only the specified fields are present in the backing JSON.
hasOptions() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
Checks whether any options are included.
hasPacketsLookedup() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
hasPacketsLookedup() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
To check whether packetLookedUp is present in this TableStatisticsEntry.
hasQfi() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Checks if the PDR has a QFI to match upon or to push on the packet.
hasSameParameters(GroupBucket) - Method in class org.onosproject.net.group.DefaultGroupBucket
 
hasSameParameters(GroupBucket) - Method in interface org.onosproject.net.group.GroupBucket
Returns whether the given group bucket has the same parameters (weight, watchPort and watchGroup) as this.
hasSelector() - Method in interface org.onosproject.net.pi.model.PiActionProfileModel
Returns true if this action profile implements dynamic selection, false otherwise.
hasStats(boolean) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
hasStats(boolean) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the stats capabilities.
HDR_FIELD_ERR - org.onosproject.cli.net.Icmp6Code
Erroneous header field encountered.
HDR_FIELD_ERR - Static variable in class org.onlab.packet.ICMP6
Erroneous header field encountered.
header() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
Return the header.
HEADER - org.onosproject.net.pi.model.PiData.Type
Header.
HEADER_LENGTH - Static variable in class org.onlab.packet.ICMP6
 
HEADER_LENGTH - Static variable in class org.onlab.packet.IGMP.IGMPv2
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ipv6.EncapSecurityPayload
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ipv6.Fragment
 
HEADER_LENGTH - Static variable in class org.onlab.packet.lacp.Lacp
 
HEADER_LENGTH - Static variable in class org.onlab.packet.lacp.LacpTlv
 
HEADER_LENGTH - Static variable in class org.onlab.packet.MPLS
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ndp.NeighborSolicitation
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ndp.Redirect
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ndp.RouterAdvertisement
 
HEADER_LENGTH - Static variable in class org.onlab.packet.ndp.RouterSolicitation
 
HEADER_LENGTH - Static variable in class org.onlab.packet.Slow
 
headerExtLength - Variable in class org.onlab.packet.ipv6.BaseOptions
 
headerExtLength - Variable in class org.onlab.packet.ipv6.Routing
 
headerLength - Variable in class org.onlab.packet.IPv4
 
headerName() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
Return the header name.
headers() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderStack
Return the list of header.
HEADERSTACK - org.onosproject.net.pi.model.PiData.Type
Header Stack.
HEADERUNION - org.onosproject.net.pi.model.PiData.Type
Header Union.
headerUnions() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnionStack
Return the collection of header union.
HEADERUNIONSTACK - org.onosproject.net.pi.model.PiData.Type
Header Union Stack.
Heap<T> - Class in org.onlab.graph
Implementation of an array-backed heap structure whose sense of order is imposed by the provided comparator.
Heap(List<T>, Comparator<T>) - Constructor for class org.onlab.graph.Heap
Creates a new heap backed by the specified list.
heapify() - Method in class org.onlab.graph.Heap
Restores the heap property by re-arranging the elements in the backing array as necessary following any heap modifications.
helpPageUrl() - Method in class org.onosproject.ui.UiView
Returns the help page URL for a specific view.
HexDump - Class in org.onlab.util
Deprecated.
in 1.11.0
HexFormatter - Class in org.onosproject.ui.table.cell
Formats integer values as hex strings with a "0x" prefix.
HexLongFormatter - Class in org.onosproject.ui.table.cell
Formats long values as hex strings with a "0x" prefix.
HexString - Class in org.onlab.util
 
HFSC - org.onosproject.net.behaviour.QosDescription.Type
Corresponds to Hierarchical Fair Service Curve classifier.
HIDDEN - org.onosproject.ui.UiView.Category
Represents views that do not show in the navigation menu.
HIGH - org.onosproject.net.packet.PacketPriority
 
HIGH1 - org.onosproject.net.packet.PacketPriority
 
HIGH2 - org.onosproject.net.packet.PacketPriority
 
HIGH3 - org.onosproject.net.packet.PacketPriority
 
HIGH4 - org.onosproject.net.packet.PacketPriority
 
HIGH5 - org.onosproject.net.packet.PacketPriority
 
higherEntry(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
higherEntry(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Returns the entry associated with the least key greater than key.
higherEntry(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the lest key greater than key.
higherKey(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
higherKey(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the lowest key greater than key.
higherKey(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the lowest key greater than key.
highestHitter(ConnectPoint) - Method in interface org.onosproject.net.statistic.StatisticService
Returns the highest hitter (a flow rule) for a given port, ie.
highlight(Enum<?>) - Method in class org.onosproject.ui.topo.BaseLink
 
highlight(Enum<?>) - Method in class org.onosproject.ui.topo.BiLink
Returns the link highlighting to use, based on this bi-link's current state.
highlightingCallback() - Method in class org.onosproject.ui.UiTopo2Overlay
Callback invoked when the topology highlighting should be updated.
Highlights - Class in org.onosproject.ui.topo
Encapsulates highlights to be applied to the topology view, such as highlighting links, displaying link labels, perhaps even decorating nodes with badges, etc.
Highlights() - Constructor for class org.onosproject.ui.topo.Highlights
 
Highlights.Amount - Enum in org.onosproject.ui.topo
A notion of amount.
highlightsMessage(Highlights) - Static method in class org.onosproject.ui.topo.TopoJson
Returns a formatted message ready to send to the topology view to render highlights.
highValue() - Method in class org.onosproject.net.pi.runtime.PiRangeFieldMatch
Returns the high value of this range field match.
hint() - Method in class org.onlab.util.PredictableExecutor.PickyFutureTask
 
hint() - Method in interface org.onlab.util.PredictableExecutor.PickyTask
Returns hint for choosing which Thread to run this task on.
hitChain() - Method in class org.onosproject.net.PipelineTraceableHitChain
Returns the hit chain.
hitChains() - Method in class org.onosproject.net.PipelineTraceableOutput
Returns the hit chains.
HM_ALLOW_DUPLICATE_IPS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_ALLOW_DUPLICATE_IPS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_GREEDY_LEARNING_IPV6 - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_GREEDY_LEARNING_IPV6_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_HOST_MOVE_COUNTER - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_HOST_MOVE_COUNTER_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_HOST_MOVE_TRACKER_ENABLE - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_HOST_MOVE_TRACKER_ENABLE_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_HOST_MOVED_THRESHOLD_IN_MILLIS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_HOST_MOVED_THRESHOLD_IN_MILLIS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_MONITOR_HOSTS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_MONITOR_HOSTS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_OFFENDING_HOST_EXPIRY_IN_MINS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_OFFENDING_HOST_EXPIRY_IN_MINS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_OFFENDING_HOST_THREADS_POOL_SIZE - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_OFFENDING_HOST_THREADS_POOL_SIZE_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_PROBE_RATE - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HM_PROBE_RATE_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
HOLDTIME_LENGTH - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
HOP - org.onosproject.cli.net.ExtHeader
Hop-by-hop header.
HOP - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Hop-by-hop header present.
HOP_LATENCY - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
Time taken for the INT packet to be switched within the device.
HOP_LIMIT_EXCEED - org.onosproject.cli.net.Icmp6Code
Hop limit exceeded in transit.
HOP_LIMIT_EXCEED - Static variable in class org.onlab.packet.ICMP6
Hop limit exceeded in transit.
HOP_WEIGHT_VALUE - Static variable in class org.onlab.graph.DefaultEdgeWeigher
Common weight value for any link.
HopByHopOptions - Class in org.onlab.packet.ipv6
Implements IPv6 Hop-by-hop Options extension header format.
HopByHopOptions() - Constructor for class org.onlab.packet.ipv6.HopByHopOptions
 
HopCountLinkWeigher - Class in org.onosproject.net.topology
Link weight for measuring link cost as hop count with indirect links being as expensive as traversing the entire graph to assume the worst.
HopCountLinkWeigher() - Constructor for class org.onosproject.net.topology.HopCountLinkWeigher
Creates a new hop-count weight.
HopCountLinkWeigher(double) - Constructor for class org.onosproject.net.topology.HopCountLinkWeigher
Creates a new hop-count weight with the specified cost of indirect links.
hopLimit - Variable in class org.onlab.packet.IPv6
 
hops - Variable in class org.onlab.packet.DHCP
 
host() - Method in class org.onosproject.cluster.DefaultControllerNode
 
host() - Method in interface org.onosproject.cluster.Node
Returns the host name of the controller instance.
host() - Method in class org.onosproject.store.cluster.messaging.Endpoint
 
host() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a host service implementation.
Host - Interface in org.onosproject.net
Abstraction of an end-station host on the network, essentially a NIC.
HOST - org.onosproject.ui.topo.TopoElementType
 
HOST_ADDED - org.onosproject.net.host.HostEvent.Type
Signifies that a new host has been detected.
HOST_ADDED_OR_UPDATED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
HOST_AUX_MOVED - org.onosproject.net.host.HostEvent.Type
Signifies that host auxiliary location has changed.
HOST_DEVICE - org.onosproject.ui.model.topo.UiLinkId.Type
 
HOST_EVENT - org.onosproject.security.AppPermission.Type
 
HOST_MOVED - org.onosproject.net.host.HostEvent.Type
Signifies that a host location has changed.
HOST_MOVED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
HOST_READ - org.onosproject.security.AppPermission.Type
 
HOST_REMOVED - org.onosproject.net.host.HostEvent.Type
Signifies that a host has been removed.
HOST_REMOVED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
HOST_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
Host ID subject factory.
HOST_SUSPENDED - org.onosproject.net.host.HostEvent.Type
Signifies that a host is in offending state, eg: frequent host movement.
HOST_UNSUSPENDED - org.onosproject.net.host.HostEvent.Type
Signifies that host state in non offending state.
HOST_UPDATED - org.onosproject.net.host.HostEvent.Type
Signifies that host data changed, e.g.
HOST_WRITE - org.onosproject.security.AppPermission.Type
 
HostAdminService - Interface in org.onosproject.net.host
Service for administering the inventory of end-station hosts.
HostAnnotationConfig - Class in org.onosproject.net.config.basics
Configuration to add extra annotations to a host via netcfg subsystem.
HostAnnotationConfig() - Constructor for class org.onosproject.net.config.basics.HostAnnotationConfig
Create a detached HostAnnotationConfig.
HostAnnotationConfig(HostId) - Constructor for class org.onosproject.net.config.basics.HostAnnotationConfig
Create a detached HostAnnotationConfig for specified host.
HostConfigOperator - Interface in org.onosproject.net.config
ConfigOperator for Host.
hostConnectPoint(String) - Static method in class org.onosproject.net.ConnectPoint
Parse a host connect point from a string.
hostCount() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the count of devices in this region.
hostCount() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the number of hosts configured in the topology.
HostDescription - Interface in org.onosproject.net.host
Information describing host and its location.
hostDetected(HostId, HostDescription, boolean) - Method in interface org.onosproject.net.host.HostProviderService
Notifies the core when a host has been detected on a network along with information that identifies the host location.
HostEvent - Class in org.onosproject.net.host
Describes end-station host event.
HostEvent(HostEvent.Type, Host) - Constructor for class org.onosproject.net.host.HostEvent
Creates an event of a given type and for the specified host and the current time.
HostEvent(HostEvent.Type, Host, long) - Constructor for class org.onosproject.net.host.HostEvent
Creates an event of a given type and for the specified host and time.
HostEvent(HostEvent.Type, Host, Host) - Constructor for class org.onosproject.net.host.HostEvent
Creates an event with previous subject.
HostEvent.Type - Enum in org.onosproject.net.host
Type of host events.
HostHighlight - Class in org.onosproject.ui.topo
Denotes the highlighting to apply to a host.
HostHighlight(String) - Constructor for class org.onosproject.ui.topo.HostHighlight
 
hostId() - Method in class org.onosproject.net.ConnectPoint
Returns the identifier of the infrastructure device if the connection point belongs to a network element which is indeed an end-station host.
hostId() - Method in class org.onosproject.net.DefaultEdgeLink
 
hostId() - Method in interface org.onosproject.net.EdgeLink
Returns the host identification.
hostId() - Method in class org.onosproject.ui.model.topo.UiEdgeLink
Returns the host identifier.
hostId(String) - Static method in class org.onosproject.net.HostId
Creates a device id using the supplied ID string.
hostId(MacAddress) - Static method in class org.onosproject.net.HostId
Creates a device id using the supplied MAC and default VLAN.
hostId(MacAddress, VlanId) - Static method in class org.onosproject.net.HostId
Creates a device id using the supplied MAC & VLAN ID.
HostId - Class in org.onosproject.net
Immutable representation of a host identity.
HostIdCompleter - Class in org.onosproject.cli.net
Host ID completer.
HostIdCompleter() - Constructor for class org.onosproject.cli.net.HostIdCompleter
 
hostIds() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the set of host identifiers for this region.
HostLearningConfig - Class in org.onosproject.net.config.basics
Configuration for enabling/disabling host learning.
HostLearningConfig() - Constructor for class org.onosproject.net.config.basics.HostLearningConfig
 
hostLearningEnabled() - Method in class org.onosproject.net.config.basics.HostLearningConfig
 
HostListener - Interface in org.onosproject.net.host
Entity capable of receiving end-station host related events.
hostLocation() - Method in class org.onosproject.net.DefaultEdgeLink
 
hostLocation() - Method in interface org.onosproject.net.EdgeLink
Returns the connection point where the host attaches to the network infrastructure.
HostLocation - Class in org.onosproject.net
Representation of a network edge location where an end-station host is connected.
HostLocation(ConnectPoint, long) - Constructor for class org.onosproject.net.HostLocation
Creates a new host location derived from the supplied connection point.
HostLocation(DeviceId, PortNumber, long) - Constructor for class org.onosproject.net.HostLocation
Creates a new host location using the supplied device & port.
HostLocationFormatter - Class in org.onosproject.ui.table.cell
Formats a host location as "(device-id)/(port)".
HostLocationSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for HostLocation.
HostLocationSerializer() - Constructor for class org.onosproject.store.serializers.HostLocationSerializer
Creates HostLocation serializer instance.
HostProbe - Interface in org.onosproject.net.host
Information related to the host being probed.
HostProbeStore - Interface in org.onosproject.net.host
Manages inventory of pending host probes.
HostProbingEvent - Class in org.onosproject.net.host
Describes host probing event.
HostProbingEvent(HostProbingEvent.Type, HostProbe) - Constructor for class org.onosproject.net.host.HostProbingEvent
Creates an event of a given type and for the specified host probe and the current time.
HostProbingEvent(HostProbingEvent.Type, HostProbe, long) - Constructor for class org.onosproject.net.host.HostProbingEvent
Creates an event of a given type and for the specified host probe and time.
HostProbingEvent(HostProbingEvent.Type, HostProbe, HostProbe) - Constructor for class org.onosproject.net.host.HostProbingEvent
Creates an event with previous subject.
HostProbingEvent(HostProbingEvent.Type, HostProbe, HostProbe, long) - Constructor for class org.onosproject.net.host.HostProbingEvent
Creates an event with previous subject and specified time.
HostProbingEvent.Type - Enum in org.onosproject.net.host
Type of host probing events.
HostProbingListener - Interface in org.onosproject.net.host
Entity capable of receiving host probing related events.
HostProbingProvider - Interface in org.onosproject.net.host
Provider of host probing.
HostProbingProviderRegistry - Interface in org.onosproject.net.host
Abstraction of a host probing provider registry.
HostProbingProviderService - Interface in org.onosproject.net.host
Means of conveying host probing information to the core.
HostProbingService - Interface in org.onosproject.net.host
Service for interacting with the host probing entities.
HostProbingStoreDelegate - Interface in org.onosproject.net.host
Host probing store delegate abstraction.
HostProvider - Interface in org.onosproject.net.host
Provider of information about hosts and their location on the network.
HostProviderRegistry - Interface in org.onosproject.net.host
Abstraction of a host provider registry.
HostProviderService - Interface in org.onosproject.net.host
Means of conveying host information to the core.
HostRemoveCommand - Class in org.onosproject.cli.net
Removes an end-station host.
HostRemoveCommand() - Constructor for class org.onosproject.cli.net.HostRemoveCommand
 
hosts() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the hosts in this region.
hosts() - Method in class org.onosproject.ui.topo.Highlights
Returns the collection of host highlights.
hosts() - Method in class org.onosproject.ui.topo.NodeSelection
Returns a view of the selected hosts (hover not included).
HOSTS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
HostsDiscovery - Interface in org.onosproject.net.behaviour
Retrieving host information from the device and creating host descriptions.
hostService - Variable in class org.onosproject.net.topology.AbstractPathService
 
HostService - Interface in org.onosproject.net.host
Service for interacting with the inventory of end-station hosts.
HostsListCommand - Class in org.onosproject.cli.net
Lists all currently-known hosts.
HostsListCommand() - Constructor for class org.onosproject.cli.net.HostsListCommand
 
HostStore - Interface in org.onosproject.net.host
Manages inventory of end-station hosts; not intended for direct use.
HostStoreDelegate - Interface in org.onosproject.net.host
Host store delegate abstraction.
hostsWithHover() - Method in class org.onosproject.ui.topo.NodeSelection
Returns a view of the selected hosts, including the hovered host if thee was one.
HostToHostIntent - Class in org.onosproject.net.intent
Abstraction of end-station to end-station bidirectional connectivity.
HostToHostIntent.Builder - Class in org.onosproject.net.intent
Builder of a host to host intent.
hostVanished(HostId) - Method in interface org.onosproject.net.host.HostProviderService
Notifies the core when a host is no longer detected on a network.
hovered() - Method in class org.onosproject.ui.topo.NodeSelection
Returns the element (link, host or device) over which the mouse was hovering, or null.
HTB - org.onosproject.net.behaviour.QosDescription.Type
Corresponds to Hierarchy token bucket classifier.
HttpResourceUrlInterceptor - Class in org.onlab.junit
Intercepts HTTP URL connections and supplies predefined data from a resource.
HttpResourceUrlInterceptor() - Constructor for class org.onlab.junit.HttpResourceUrlInterceptor
 
HttpResourceUrlInterceptor.HttpResourceUrlInterceptorFactory - Class in org.onlab.junit
Creates stream handlers for the interceptor.
HttpResourceUrlInterceptorFactory(String) - Constructor for class org.onlab.junit.HttpResourceUrlInterceptor.HttpResourceUrlInterceptorFactory
 
humanReadable(long) - Static method in class org.onosproject.cli.net.DevicePortStatsCommand
Converts bytes to human readable string with Kilo, Mega, Giga, etc.
humanReadableBps(float) - Static method in class org.onosproject.cli.net.DevicePortStatsCommand
Converts bps to human readable format.
humanReadableName() - Method in enum org.onosproject.net.pi.runtime.PiEntityType
Returns a human readable representation of this PI entity type (useful for logging).
humanReadableName() - Method in enum org.onosproject.net.pi.runtime.PiMeterBandType
Returns a human readable representation of this PI meter band type (useful for logging).
HW_TYPE_ETHERNET - Static variable in class org.onlab.packet.ARP
 
HW_VERSION - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
hwAddress() - Method in class org.onosproject.net.host.DefaultHostDescription
 
hwAddress() - Method in interface org.onosproject.net.host.HostDescription
Returns the MAC address associated with this host (NIC).
HWTYPE_ETHERNET - Static variable in class org.onlab.packet.DHCP
 
hwVersion() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device hardware version.
hwVersion() - Method in class org.onosproject.net.DefaultDevice
 
hwVersion() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
hwVersion() - Method in interface org.onosproject.net.device.DeviceDescription
Returns the device hardware version.
hwVersion() - Method in interface org.onosproject.net.Device
Returns the device hardware version.
hwVersion() - Method in class org.onosproject.net.driver.DefaultDriver
 
hwVersion() - Method in interface org.onosproject.net.driver.Driver
Returns the device hardware version.
hwVersion() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
hwVersion(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device hardware version.
HybridLogicalClockService - Interface in org.onosproject.core
The hybrid logical time keeper service.
HybridLogicalTime - Class in org.onosproject.core
Time provided by a Hybrid Logical Clock described in this paper.
HybridLogicalTime(long, long) - Constructor for class org.onosproject.core.HybridLogicalTime
 

I

IA_NA - org.onlab.packet.DHCP6.OptionCode
 
IA_PD - org.onlab.packet.DHCP6.OptionCode
 
IA_TA - org.onlab.packet.DHCP6.OptionCode
 
IAADDR - org.onlab.packet.DHCP6.OptionCode
 
IAPREFIX - org.onlab.packet.DHCP6.OptionCode
 
ICMP - Class in org.onlab.packet
Implements ICMP packet format.
ICMP - org.onosproject.cli.net.IpProtocol
ICMP.
ICMP() - Constructor for class org.onlab.packet.ICMP
 
ICMP_ECHO_HEADER_LENGTH - Static variable in class org.onlab.packet.ICMPEcho
 
ICMP_HEADER_LENGTH - Static variable in class org.onlab.packet.ICMP
 
ICMP6 - Class in org.onlab.packet
Implements ICMPv6 packet format.
ICMP6 - org.onosproject.cli.net.IpProtocol
ICMP6.
ICMP6() - Constructor for class org.onlab.packet.ICMP6
 
Icmp6Code - Enum in org.onosproject.cli.net
Known values for ICMPv6 code field that can be supplied to the CLI.
Icmp6CodeCompleter - Class in org.onosproject.cli.net
ICMPv6 type completer.
Icmp6CodeCompleter() - Constructor for class org.onosproject.cli.net.Icmp6CodeCompleter
 
Icmp6PacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
Icmp6PacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.Icmp6PacketClassifier
 
Icmp6Type - Enum in org.onosproject.cli.net
Known values for ICMPv6 type field that can be supplied to the CLI.
Icmp6TypeCompleter - Class in org.onosproject.cli.net
ICMPv6 type completer.
Icmp6TypeCompleter() - Constructor for class org.onosproject.cli.net.Icmp6TypeCompleter
 
icmpCode - Variable in class org.onlab.packet.ICMP
 
icmpCode - Variable in class org.onlab.packet.ICMP6
 
icmpCode() - Method in class org.onosproject.net.flow.criteria.IcmpCodeCriterion
Gets the ICMP code to match.
IcmpCodeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of ICMP code criterion (8 bits unsigned integer).
ICMPEcho - Class in org.onlab.packet
ICMP packet class for echo purpose.
ICMPEcho() - Constructor for class org.onlab.packet.ICMPEcho
 
IcmpPacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
IcmpPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.IcmpPacketClassifier
 
icmpType - Variable in class org.onlab.packet.ICMP
 
icmpType - Variable in class org.onlab.packet.ICMP6
 
icmpType() - Method in class org.onosproject.net.flow.criteria.IcmpTypeCriterion
Gets the ICMP type to match.
IcmpTypeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of ICMP type criterion (8 bits unsigned integer).
ICMPV4_CODE - org.onosproject.net.flow.criteria.Criterion.Type
ICMP code.
ICMPV4_TYPE - org.onosproject.net.flow.criteria.Criterion.Type
ICMP type.
ICMPV6_CODE - org.onosproject.net.flow.criteria.Criterion.Type
ICMPv6 code.
ICMPV6_TYPE - org.onosproject.net.flow.criteria.Criterion.Type
ICMPv6 type.
icmpv6Code() - Method in class org.onosproject.net.flow.criteria.Icmpv6CodeCriterion
Gets the ICMPv6 code to match.
Icmpv6CodeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of ICMPv6 code criterion (8 bits unsigned integer).
icmpv6Type() - Method in class org.onosproject.net.flow.criteria.Icmpv6TypeCriterion
Gets the ICMPv6 type to match.
Icmpv6TypeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of ICMPv6 type criterion (8 bits unsigned integer).
icon() - Method in interface org.onosproject.app.ApplicationDescription
Returns icon of the application.
icon() - Method in class org.onosproject.app.DefaultApplicationDescription
 
icon() - Method in interface org.onosproject.core.Application
Returns icon of the application.
icon() - Method in class org.onosproject.core.DefaultApplication
 
iconId() - Method in class org.onosproject.ui.UiView
Returns the icon identifier.
ICR_COPY_TTL - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_COPY_TTL_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_FLOW_OPTIMIZATION - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_FLOW_OPTIMIZATION_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_LABEL_SELECTION - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_LABEL_SELECTION_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_OPT_LABEL_SELECTION - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_OPT_LABEL_SELECTION_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_USE_FLOW_OBJECTIVES - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICR_USE_FLOW_OBJECTIVES_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICU_ENABLED - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICU_ENABLED_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICU_PERIOD - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICU_PERIOD_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICU_RETRY_THRESHOLD - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ICU_RETRY_THRESHOLD_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
id - Variable in class org.onosproject.net.AbstractElement
 
id - Variable in class org.onosproject.ui.model.topo.UiLink
 
id() - Method in class org.onlab.util.Identifier
Returns the backing identifier value.
id() - Method in interface org.onosproject.alarm.Alarm
Returns the unique alarm id within this ONOS instance.
id() - Method in class org.onosproject.alarm.DefaultAlarm
 
id() - Method in class org.onosproject.cluster.DefaultControllerNode
 
id() - Method in interface org.onosproject.cluster.Node
Returns the instance identifier.
id() - Method in interface org.onosproject.core.Application
Returns the application name id.
id() - Method in interface org.onosproject.core.ApplicationId
Returns the application id.
id() - Method in class org.onosproject.core.DefaultApplication
 
id() - Method in class org.onosproject.core.DefaultApplicationId
 
id() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState
id() - Method in class org.onosproject.net.DefaultDevice
 
id() - Method in class org.onosproject.net.DefaultHost
 
id() - Method in interface org.onosproject.net.Device
Returns the device identifier.
id() - Method in interface org.onosproject.net.Element
Returns the network element identifier.
id() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
id() - Method in interface org.onosproject.net.flow.FlowRule
Returns the ID of this flow.
id() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry
Deprecated.
 
id() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchOperation
Deprecated.
 
id() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
id() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
id() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
id() - Method in interface org.onosproject.net.flowobjective.Objective
An identifier for this objective.
id() - Method in class org.onosproject.net.group.DefaultGroup
Returns group identifier associated with a group object.
id() - Method in interface org.onosproject.net.group.Group
Returns group identifier associated with a group object.
id() - Method in interface org.onosproject.net.Host
Host identification.
id() - Method in class org.onosproject.net.intent.Intent
Returns the intent object identifier.
id() - Method in class org.onosproject.net.meter.DefaultMeter
 
id() - Method in interface org.onosproject.net.meter.Meter
Deprecated.
in Nightingale release (version 1.13.0). Use Meter.meterCellId() instead.
id() - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
 
id() - Method in interface org.onosproject.net.pi.model.PiActionModel
Returns the ID of the action.
id() - Method in interface org.onosproject.net.pi.model.PiActionParamModel
Returns the ID of this action parameter.
id() - Method in interface org.onosproject.net.pi.model.PiActionProfileModel
Returns the ID of this action profile.
id() - Method in interface org.onosproject.net.pi.model.PiCounterModel
Returns the ID of this counter.
id() - Method in interface org.onosproject.net.pi.model.PiMatchFieldModel
Returns the ID of this match field.
id() - Method in interface org.onosproject.net.pi.model.PiMeterModel
Returns the ID of this meter.
id() - Method in interface org.onosproject.net.pi.model.PiPacketMetadataModel
Returns the ID of this packet metadata.
id() - Method in interface org.onosproject.net.pi.model.PiPipeconf
Returns the identifier of this pipeline configuration.
id() - Method in interface org.onosproject.net.pi.model.PiRegisterModel
Returns the ID of this register.
id() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns the ID of this table.
id() - Method in class org.onosproject.net.pi.runtime.PiAction
Return the identifier of this action.
id() - Method in class org.onosproject.net.pi.runtime.PiActionParam
Returns the identifier of this parameter.
id() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
Returns the ID of this action profile group.
id() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
Returns the ID of the action profile member.
id() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
Returns the identifier of this member.
id() - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata
Return the identifier of this packet metadata.
id() - Method in class org.onosproject.net.provider.AbstractProvider
 
id() - Method in interface org.onosproject.net.provider.Provider
Returns the provider identifier.
id() - Method in class org.onosproject.net.provider.ProviderId
Returns the device URI scheme specific id portion.
id() - Method in class org.onosproject.net.region.DefaultRegion
 
id() - Method in interface org.onosproject.net.region.Region
Returns the unique identifier of the region.
id() - Method in class org.onosproject.net.resource.ContinuousFactory
Returns the resource ID for continuous-type.
id() - Method in class org.onosproject.net.resource.ContinuousResource
 
id() - Method in class org.onosproject.net.resource.DiscreteFactory
Returns the resource ID for discrete-type.
id() - Method in class org.onosproject.net.resource.DiscreteResource
 
id() - Method in interface org.onosproject.net.resource.Resource
Returns the ID of this resource.
id() - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
id() - Method in interface org.onosproject.net.topology.TopologyCluster
Returns the cluster id.
id() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
id() - Method in class org.onosproject.store.service.PartitionInfo
Returns the partition ID.
id() - Method in class org.onosproject.ui.lion.LionBundle.Builder
Returns the bundle ID.
id() - Method in class org.onosproject.ui.lion.LionBundle
Returns the bundle's identifier.
id() - Method in class org.onosproject.ui.model.topo.UiClusterMember
Returns the identity of the cluster member.
id() - Method in class org.onosproject.ui.model.topo.UiDevice
Returns the identity of the device.
id() - Method in class org.onosproject.ui.model.topo.UiHost
Returns the identity of the host.
id() - Method in class org.onosproject.ui.model.topo.UiLink
Returns the canonicalized link identifier for this link.
id() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the identity of the region.
id() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the UI layout identifier.
id() - Method in class org.onosproject.ui.topo.LayoutLocation
Returns the identifier associated with this location.
id() - Method in class org.onosproject.ui.topo.PropertyPanel
Returns the internal ID.
id() - Method in class org.onosproject.ui.UiGlyph
Returns the identifier for this glyph.
id() - Method in class org.onosproject.ui.UiTopo2Overlay
Returns the identifier for this overlay.
id() - Method in class org.onosproject.ui.UiTopoMap
Returns the identifier for this map.
id() - Method in class org.onosproject.ui.UiTopoOverlay
Returns the identifier for this overlay.
id() - Method in class org.onosproject.ui.UiView
Returns the view identifier.
id(String) - Method in class org.onosproject.ui.topo.PropertyPanel
Adds an ID field to the panel data, to be included in the returned JSON data to the client.
ID - org.onosproject.net.flowobjective.NextTreatment.Type
The next action is specified by an Integer next id.
ID - Static variable in class org.onosproject.ui.GlyphConstants
 
ID_GENERATOR - org.onosproject.store.service.DistributedPrimitive.Type
Numeric ID generator.
idA() - Method in class org.onosproject.ui.model.topo.UiLinkId
String representation of endpoint A.
idAsString() - Method in class org.onosproject.ui.model.topo.UiClusterMember
 
idAsString() - Method in class org.onosproject.ui.model.topo.UiDevice
 
idAsString() - Method in class org.onosproject.ui.model.topo.UiElement
Returns a string representation of the element identifier.
idAsString() - Method in class org.onosproject.ui.model.topo.UiHost
 
idAsString() - Method in class org.onosproject.ui.model.topo.UiLink
 
idAsString() - Method in class org.onosproject.ui.model.topo.UiRegion
 
idAsString() - Method in class org.onosproject.ui.model.topo.UiTopology
 
idB() - Method in class org.onosproject.ui.model.topo.UiLinkId
String representation of endpoint B.
IdBlock - Class in org.onosproject.core
A class representing an ID space.
IdBlock(long, long) - Constructor for class org.onosproject.core.IdBlock
Constructs a new ID block with the specified size and initial value.
IdBlockStore - Interface in org.onosproject.core
Manages id blocks.
identification - Variable in class org.onlab.packet.IPv4
 
identification - Variable in class org.onlab.packet.ipv6.Fragment
 
identifier - Variable in class org.onlab.packet.EAP
 
identifier - Variable in class org.onlab.packet.RADIUS
 
identifier - Variable in class org.onlab.util.Identifier
 
Identifier<T> - Class in org.onlab.util
Abstract identifier backed by another value, e.g.
Identifier() - Constructor for class org.onlab.util.Identifier
Constructor for serialization.
Identifier(T) - Constructor for class org.onlab.util.Identifier
Constructs an identifier backed by the specified value.
IdGenerator - Interface in org.onosproject.core
A generalized interface for ID generation IdGenerator.getNewId() generates a globally unique ID instance on each invocation.
IDLE_TIME - org.onosproject.net.flow.StatTriggerField
Time flow entry has been idle.
IDLE_TIMEOUT - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
IdNextTreatment - Class in org.onosproject.net.flowobjective
Represents a next action specified by next id.
IDS - org.onosproject.net.Device.Type
 
idStore - Variable in class org.onosproject.store.app.DistributedApplicationStore
 
IExtensionHeader - Interface in org.onlab.packet.ipv6
Interface for IPv6 extension header.
ifaceName() - Method in class org.onosproject.net.behaviour.DefaultPatchDescription
 
ifaceName() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
ifaceName() - Method in interface org.onosproject.net.behaviour.PatchDescription
Return the name of the patch interface.
ifaceName() - Method in interface org.onosproject.net.behaviour.TunnelDescription
Return the name of the tunnel interface.
ifaceName(String) - Method in class org.onosproject.net.behaviour.DefaultPatchDescription.Builder
 
ifaceName(String) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
ifaceName(String) - Method in interface org.onosproject.net.behaviour.PatchDescription.Builder
Returns patch interface description builder with a given interface name.
ifaceName(String) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface description builder with a given interface name.
ifNotNull() - Static method in class org.onlab.util.Match
Returns a Match that matches all non-null values.
ifNotValue(T) - Static method in class org.onlab.util.Match
Returns a Match that matches any value except the specified value.
ifNull() - Static method in class org.onlab.util.Match
Returns a Match that matches null values.
IFOM_OBJ_TIMEOUT_MS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
IFOM_OBJ_TIMEOUT_MS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
ifValue(T) - Static method in class org.onlab.util.Match
Returns a Match that only matches the specified value.
IGMP - Class in org.onlab.packet
Implements IGMP control packet format.
IGMP - org.onosproject.net.mcast.McastRoute.Type
Deprecated.
Route originates from IGMP.
IGMP() - Constructor for class org.onlab.packet.IGMP
 
IGMP.IGMPv2 - Class in org.onlab.packet
 
IGMP.IGMPv3 - Class in org.onlab.packet
 
IGMPGroup - Class in org.onlab.packet
A class to represent Groups for membership query and reports.
IGMPGroup() - Constructor for class org.onlab.packet.IGMPGroup
 
IGMPGroup(IpAddress, int) - Constructor for class org.onlab.packet.IGMPGroup
Initialize this object with a multicast group address and additional info.
IGMPMembership - Class in org.onlab.packet
 
IGMPMembership() - Constructor for class org.onlab.packet.IGMPMembership
Default constructor.
IGMPMembership(Ip4Address) - Constructor for class org.onlab.packet.IGMPMembership
Constructor initialized with a multicast group address.
IGMPQuery - Class in org.onlab.packet
 
IGMPQuery() - Constructor for class org.onlab.packet.IGMPQuery
Create IGMP Query message.
IGMPQuery(IpAddress, int) - Constructor for class org.onlab.packet.IGMPQuery
Create IGMP Query message.
igmpType - Variable in class org.onlab.packet.IGMP
 
IGMPv2() - Constructor for class org.onlab.packet.IGMP.IGMPv2
 
IGMPv3() - Constructor for class org.onlab.packet.IGMP.IGMPv3
 
IllegalArgumentExceptionMapper - Class in org.onlab.rest.exceptions
Mapper for illegal argument exceptions to the BAD_REQUEST response code.
IllegalArgumentExceptionMapper() - Constructor for class org.onlab.rest.exceptions.IllegalArgumentExceptionMapper
 
IllegalDocumentModificationException - Exception in org.onosproject.store.service
An exception to be thrown when a node cannot be removed normally because it does not exist or because it is not a leaf node.
IllegalDocumentModificationException() - Constructor for exception org.onosproject.store.service.IllegalDocumentModificationException
 
IllegalDocumentModificationException(String) - Constructor for exception org.onosproject.store.service.IllegalDocumentModificationException
 
IllegalDocumentModificationException(String, Throwable) - Constructor for exception org.onosproject.store.service.IllegalDocumentModificationException
 
IllegalDocumentModificationException(Throwable) - Constructor for exception org.onosproject.store.service.IllegalDocumentModificationException
 
IllegalDocumentNameException - Exception in org.onosproject.store.service
An exception thrown when an illegally named node is submitted.
IllegalDocumentNameException() - Constructor for exception org.onosproject.store.service.IllegalDocumentNameException
 
IllegalDocumentNameException(String) - Constructor for exception org.onosproject.store.service.IllegalDocumentNameException
 
IllegalDocumentNameException(String, Throwable) - Constructor for exception org.onosproject.store.service.IllegalDocumentNameException
 
IllegalDocumentNameException(Throwable) - Constructor for exception org.onosproject.store.service.IllegalDocumentNameException
 
IllegalStateExceptionMapper - Class in org.onlab.rest.exceptions
Mapper for illegal state exceptions to the BAD_REQUEST response code.
IllegalStateExceptionMapper() - Constructor for class org.onlab.rest.exceptions.IllegalStateExceptionMapper
 
IM_NUM_THREADS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
IM_NUM_THREADS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
IM_SKIP_RELEASE_RESOURCES_ON_WITHDRAWAL - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
IM_SKIP_RELEASE_RESOURCES_ON_WITHDRAWAL_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
imageUrl() - Method in interface org.onosproject.core.Application
Returns binary image URL.
imageUrl() - Method in class org.onosproject.core.DefaultApplication
 
immediate() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
immediate() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
immediate() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Any instructions followed by this method call will be immediate.
immediate() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the list of treatment instructions that will be applied immediately.
IMMEDIATE - org.onlab.packet.IPPrecedence
 
IMMEDIATE - org.onosproject.net.flow.FlowEntry.FlowLiveType
Indicates that this rule has been submitted for addition immediately.
IMMEDIATE_FLOW - org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Indicates that this rule has been submitted for addition immediately.
immediateLoad() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Returns immediate load of connect point.
ImmutableByteSequence - Class in org.onlab.util
Immutable sequence of bytes, assumed to represent a value in BIG_ENDIAN order.
ImmutableByteSequence.ByteSequenceTrimException - Exception in org.onlab.util
Signals a trim exception during byte sequence creation.
ImmutableByteSequenceSerializer - Class in org.onosproject.store.serializers
Kryo serializer for ImmutableByteSequence.
ImmutableByteSequenceSerializer() - Constructor for class org.onosproject.store.serializers.ImmutableByteSequenceSerializer
Creates a new ImmutableByteSequence serializer instance.
ImmutableClassChecker - Class in org.onlab.junit
Hamcrest style class for verifying that a class follows the accepted rules for immutable classes.
ImmutableClassChecker() - Constructor for class org.onlab.junit.ImmutableClassChecker
 
ImmutableListSerializer - Class in org.onosproject.store.serializers
Creates ImmutableList serializer instance.
ImmutableListSerializer() - Constructor for class org.onosproject.store.serializers.ImmutableListSerializer
Creates ImmutableList serializer instance.
ImmutableMapSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for ImmutableMap.
ImmutableMapSerializer() - Constructor for class org.onosproject.store.serializers.ImmutableMapSerializer
Creates ImmutableMap serializer instance.
ImmutableSetSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for ImmutableSet.
ImmutableSetSerializer() - Constructor for class org.onosproject.store.serializers.ImmutableSetSerializer
Creates ImmutableSet serializer instance.
implementation(Class<? extends Behaviour>) - Method in class org.onosproject.net.driver.DefaultDriver
 
implementation(Class<? extends Behaviour>) - Method in interface org.onosproject.net.driver.Driver
Returns the implementation class for the specified behaviour.
implementation(Class<? extends Behaviour>) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
 
implementation(Class<? extends Behaviour>) - Method in interface org.onosproject.net.pi.model.PiPipeconf
Returns the implementation class for the given behaviour, if present.
IMPORT_EXTRANEOUS_RULES - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
IMPORT_EXTRANEOUS_RULES_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
IN_PHY_PORT - org.onosproject.net.flow.criteria.Criterion.Type
Switch physical input port.
IN_PORT - org.onosproject.net.flow.criteria.Criterion.Type
Switch input port.
IN_PORT - org.onosproject.net.PortNumber.Logical
 
IN_PORT - Static variable in class org.onosproject.net.PortNumber
 
INACTIVE - org.onosproject.cluster.ControllerNode.State
Signifies that the instance is inactive, which means either down or up, but not operational.
INACTIVE - org.onosproject.net.Link.State
Signifies that a link is currently inactive.
INACTIVE - org.onosproject.store.service.DistributedPrimitive.Status
Signifies a state wherein the primitive has been shutdown and therefore cannot perform its functions.
INACTIVE - org.onosproject.upgrade.Upgrade.Status
Represents state in which no upgrade has been initialized.
INBOUND_PACKET - org.onosproject.cpman.ControlMessage.Type
 
INBOUND_PACKET - org.onosproject.cpman.ControlMetricType
 
InboundPacket - Interface in org.onosproject.net.packet
Represents a data packet intercepted from an infrastructure device.
incrementAndGet() - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
 
incrementAndGet() - Method in interface org.onosproject.store.service.AsyncAtomicCounter
Atomically increment by one the current value.
incrementAndGet() - Method in interface org.onosproject.store.service.AtomicCounter
Atomically increment by one the current value.
incrementAndGet(K) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
incrementAndGet(K) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Increments by one the value currently associated with key, and returns the new value.
incrementAndGet(K) - Method in interface org.onosproject.store.service.AtomicCounterMap
Increments by one the value currently associated with key, and returns the new value.
incrementCount() - Method in class org.onlab.util.SlidingWindowCounter
Increments the count of the current window slot by 1.
incrementCount(long) - Method in class org.onlab.util.SlidingWindowCounter
Increments the count of the current window slot by the given value.
incrementErrorCount() - Method in class org.onosproject.net.intent.IntentData
Increments the error count for this intent.
incrFailedRetryCount() - Method in class org.onosproject.net.group.DefaultGroup
 
incrFailedRetryCount() - Method in interface org.onosproject.net.group.StoredGroupEntry
Increments the count for the number of failed attempts in programming this group.
INDETERMINATE - org.onosproject.alarm.Alarm.SeverityLevel
From X.733: This indicates that the severity level cannot be determined.
index() - Method in class org.onosproject.net.meter.DefaultMeterRequest
 
index() - Method in interface org.onosproject.net.meter.MeterRequest
Returns the desired meter index of this meter request.
index() - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
Returns the counter index to which this cell ID is associated.
index() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
Returns the meter index to which this cell ID is associated.
index() - Method in class org.onosproject.net.pi.runtime.PiRegisterCellId
Returns the register index to which this cell ID is associated.
index() - Method in class org.onosproject.net.topology.ClusterId
Returns the backing integer index.
index() - Method in class org.onosproject.net.TributarySlot
Returns the index number of TributarySlot.
INDEX - org.onosproject.net.flow.TableId.Type
Signifies that the table identifier corresponds to the position of the table in the pipeline.
INDEX - org.onosproject.net.meter.MeterCellId.MeterCellType
Signifies that the meter cell can be identified with an integer index.
IndexTableId - Class in org.onosproject.net.flow
Table identifier representing the position of the table in the pipeline.
INDIRECT - org.onosproject.net.group.GroupDescription.Type
Single Bucket Group.
INDIRECT - org.onosproject.net.Link.Type
Signifies that this link is potentially comprised from multiple underlying segments or hops, and as such should be used to tag links traversing optical paths, tunnels or intervening 'dark' switches.
INDIRECT - org.onosproject.net.pi.model.PiCounterType
Identifies a counter not associated with any other resource.
INDIRECT - org.onosproject.net.pi.model.PiMeterType
Identifies a meter not associated with any other resource.
INDIRECT - org.onosproject.net.pi.model.PiTableType
Implementation-based table, e.g.
INET - org.onlab.packet.IpAddress.Version
 
INET_BIT_LENGTH - Static variable in class org.onlab.packet.IpAddress
 
INET_BYTE_LENGTH - Static variable in class org.onlab.packet.IpAddress
 
INET6 - org.onlab.packet.IpAddress.Version
 
INET6_BIT_LENGTH - Static variable in class org.onlab.packet.IpAddress
 
INET6_BYTE_LENGTH - Static variable in class org.onlab.packet.IpAddress
 
INFINITY_METRIC - Static variable in class org.onlab.packet.RIPngEntry
 
INFINITY_METRIC - Static variable in class org.onlab.packet.RIPV2Entry
 
info() - Method in class org.onosproject.routing.InterfaceProvisionRequest
Retrieves the router configuration info.
info() - Method in class org.onosproject.routing.Router
Retrieves the router configuration information.
info(String) - Method in class org.onlab.junit.LoggerAdapter
 
info(String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
info(String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
info(String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
info(String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
info(Marker, String) - Method in class org.onlab.junit.LoggerAdapter
 
info(Marker, String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
info(Marker, String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
info(Marker, String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
info(Marker, String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
INFO - org.onlab.util.Tools.LogLevel
 
INFO - org.onosproject.ui.topo.NodeBadge.Status
 
INFORMATION_REQUEST - org.onlab.packet.DHCP6.MsgType
 
INGRESS - org.onosproject.net.Direction
 
INGRESS_TIMESTAMP - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
The device local time when the INT packet was received on the ingress port.
ingressPacket() - Method in class org.onosproject.net.PipelineTraceableInput
Getter for the ingress packet.
ingressPoint() - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
Returns the port on which the ingress traffic should be connected to the egress.
ingressPoints() - Method in class org.onosproject.net.intent.LinkCollectionIntent
Returns the ingress points of the intent.
ingressPoints() - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
Returns the set of ports on which ingress traffic should be connected to the egress port.
ingressPort() - Method in class org.onosproject.net.PipelineTraceableInput
Getter for the ingress port.
ingressVlan() - Method in class org.onosproject.net.config.basics.McastConfig
Gets ingress VLAN of multicast traffic.
init() - Method in class org.onosproject.cli.net.TopologyCommand
Initializes the context for all cluster commands.
init() - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
Initializes the pipeline, by installing required flow rules not relevant to specific watchlist, report and event.
init() - Method in interface org.onosproject.net.behaviour.PipelineTraceable
Initializes the traceable with a context required for its operation.
init() - Method in interface org.onosproject.net.behaviour.upf.UpfProgrammable
Apps are expected to call this method as the first one when they are ready to install PDRs and FARs.
init() - Method in class org.onosproject.ui.UiTopo2Overlay
Callback invoked to initialize this overlay, soon after creation.
init() - Method in class org.onosproject.ui.UiTopoOverlay
Callback invoked to initialize this overlay, soon after creation.
init(ApplicationId) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Provision rules to punt BNG control packets to ONOS.
init(DeviceId, PipelinerContext) - Method in interface org.onosproject.net.behaviour.Pipeliner
Initializes the driver with context required for its operation.
init(UiConnection, ServiceDirectory) - Method in class org.onosproject.ui.UiMessageHandler
Initializes the handler with the user interface connection and service directory context.
init(S, String, JsonNode, ObjectMapper, ConfigApplyDelegate) - Method in class org.onosproject.net.config.Config
Initializes the configuration behaviour with necessary context.
INITIAL_HEADER_LENGTH - Static variable in class org.onlab.packet.ARP
 
INITIAL_HEADER_REQUIRED - Static variable in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
INITIAL_ID - Static variable in class org.onlab.util.KryoNamespace
Smallest ID free to use for user defined registrations.
initialize() - Method in interface org.onosproject.upgrade.UpgradeAdminService
Initializes an upgrade.
INITIALIZED - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade has been initialized.
INITIALIZED - org.onosproject.upgrade.UpgradeEvent.Type
Indicates that a new upgrade was initialized.
INITIALIZING - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade is being initialized.
initPolicy(String) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Provides a composition policy expression.
INNER_VLAN_PCP - org.onosproject.net.flow.criteria.Criterion.Type
Inner VLAN pcp.
INNER_VLAN_VID - org.onosproject.net.flow.criteria.Criterion.Type
Inner VLAN id.
InnerOrderedResult(V, V) - Constructor for class org.onlab.graph.KShortestPathsSearch.InnerOrderedResult
 
InnerOrderedResult(V, V, int) - Constructor for class org.onlab.graph.KShortestPathsSearch.InnerOrderedResult
 
innerVlan() - Method in class org.onosproject.net.config.basics.BasicHostConfig
 
innerVlan() - Method in class org.onosproject.net.DefaultHost
 
innerVlan() - Method in class org.onosproject.net.host.DefaultHostDescription
 
innerVlan() - Method in interface org.onosproject.net.host.HostDescription
Returns the inner VLAN associated with this host.
innerVlan() - Method in interface org.onosproject.net.Host
Returns the inner VLAN ID tied to this host.
inPacket() - Method in class org.onosproject.net.packet.DefaultPacketContext
 
inPacket() - Method in interface org.onosproject.net.packet.PacketContext
Returns the inbound packet being processed.
inPort() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the port where the packet came in to the network.
inPort() - Method in class org.onosproject.net.packet.DefaultOutboundPacket
 
inPort() - Method in interface org.onosproject.net.packet.OutboundPacket
Returns the input port of this packet.
inRange(MacAddress, MacAddress) - Method in class org.onlab.packet.MacAddress
Checks if the Mac Address is inside a range defined by macAddr and mask.
insert(T) - Method in class org.onlab.graph.Heap
Inserts the specified item into the heap and returns the modified heap.
INSERT - org.onosproject.store.service.MapEvent.Type
Entry inserted into the map.
INSERT - org.onosproject.store.service.MultimapEvent.Type
Entry inserted into the map.
insertEdge(E) - Method in class org.onlab.graph.DefaultMutablePath
 
insertEdge(E) - Method in interface org.onlab.graph.MutablePath
Inserts a new edge at the beginning of this path.
INSERTION - org.onosproject.store.service.Ordering
Indicates that items should be ordered in insertion order.
insertOrReplace(E, Predicate<E>) - Method in class org.onlab.util.ExtendedSet
Inserts the entry if it is not already in the set otherwise replaces the existing entry if the supplied predicate evaluates to true.
insertQueues(QosId, Map<Long, QueueDescription>) - Method in interface org.onosproject.net.behaviour.QosConfigBehaviour
bind queue to qos.
install(InputStream) - Method in interface org.onosproject.app.ApplicationAdminService
Installs the application contained in the specified application archive input stream.
INSTALL_REQ - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent is to be installed or reinstalled.
INSTALL_REQ - org.onosproject.net.intent.IntentState
Signifies that the intent has been submitted and will start compiling shortly.
installables() - Method in class org.onosproject.net.intent.IntentData
Returns the installables associated with this intent.
INSTALLATIONTHRESHOLDEXCEEDED - org.onosproject.net.flowobjective.ObjectiveError
Flow/Group installation retry threshold exceeded.
INSTALLATIONTIMEOUT - org.onosproject.net.flowobjective.ObjectiveError
Installation timeout.
INSTALLED - org.onosproject.app.ApplicationState
Indicates that application has been installed, but is not running.
INSTALLED - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent has been successfully installed.
INSTALLED - org.onosproject.net.intent.IntentState
The intent has been successfully installed.
INSTALLED - org.onosproject.store.app.DistributedApplicationStore.InternalState
 
INSTALLING - org.onosproject.net.intent.IntentState
Signifies that the resulting installable intents are being installed into the network environment.
instance() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
If present, returns the instance of the action profile member pointed by this reference, otherwise returns null.
instance() - Method in enum org.onosproject.net.PortNumber.Logical
PortNumber instance for the logical port.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.AppIdFormatter
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.ConnectPointFormatter
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.DefaultCellComparator
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.DefaultCellFormatter
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.EnumFormatter
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.HexFormatter
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.HexLongFormatter
An instance of this class.
INSTANCE - Static variable in class org.onosproject.ui.table.cell.HostLocationFormatter
An instance of this class.
INSTANCE_ACTIVATED - org.onosproject.cluster.ClusterEvent.Type
Signifies that a cluster instance became active.
INSTANCE_ADDED - org.onosproject.cluster.ClusterEvent.Type
Signifies that a new cluster instance has been administratively added.
INSTANCE_DEACTIVATED - org.onosproject.cluster.ClusterEvent.Type
Signifies that a cluster instance became inactive.
INSTANCE_READY - org.onosproject.cluster.ClusterEvent.Type
Signifies that a cluster instance became ready.
INSTANCE_REMOVED - org.onosproject.cluster.ClusterEvent.Type
Signifies that a cluster instance has been administratively removed.
instanceId() - Method in class org.onosproject.net.pi.runtime.PiPreReplica
Returns the instance ID of this replica.
instanceType() - Method in class org.onosproject.cluster.ClusterEvent
Returns the instance type subject.
Instruction - Interface in org.onosproject.net.flow.instructions
Abstraction of a single traffic treatment step.
Instruction.Type - Enum in org.onosproject.net.flow.instructions
Represents the type of traffic treatment.
Instructions - Class in org.onosproject.net.flow.instructions
Factory class for creating various traffic treatment instructions.
Instructions.ExtensionInstructionWrapper - Class in org.onosproject.net.flow.instructions
Extension instruction.
Instructions.GroupInstruction - Class in org.onosproject.net.flow.instructions
Group Instruction.
Instructions.MetadataInstruction - Class in org.onosproject.net.flow.instructions
Metadata instruction.
Instructions.MeterInstruction - Class in org.onosproject.net.flow.instructions
A meter instruction.
Instructions.NoActionInstruction - Class in org.onosproject.net.flow.instructions
No Action instruction.
Instructions.OutputInstruction - Class in org.onosproject.net.flow.instructions
Output Instruction.
Instructions.SetQueueInstruction - Class in org.onosproject.net.flow.instructions
Set-Queue Instruction.
Instructions.StatTriggerInstruction - Class in org.onosproject.net.flow.instructions
 
Instructions.TableTypeTransition - Class in org.onosproject.net.flow.instructions
Transition instruction.
Instructions.TruncateInstruction - Class in org.onosproject.net.flow.instructions
 
INT - org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.TelemetrySpec
Embeds telemetry metadata according to the INT specification.
IntDeviceConfig - Class in org.onosproject.net.behaviour.inbandtelemetry
Device-level configuration of the INT process.
IntDeviceConfig.Builder - Class in org.onosproject.net.behaviour.inbandtelemetry
An IntConfig object builder.
IntDeviceConfig.TelemetrySpec - Enum in org.onosproject.net.behaviour.inbandtelemetry
Represents a type of telemetry spec to collect in the dataplane.
INTEGER - org.onosproject.cfg.ConfigProperty.Type
Indicates the value is an integer.
INTEGER - Static variable in class org.onosproject.ui.table.cell.NumberFormatter
An instance of this class that formats as integers (no decimal places).
IntegrationTest - Interface in org.onlab.junit
Marker interface used to separate unit tests from integration tests.
integrityCheck - Variable in class org.onlab.packet.ipv6.Authentication
 
intent() - Method in class org.onosproject.net.domain.DomainIntentOperation
Returns the domain intent.
intent() - Method in class org.onosproject.net.intent.IntentData
Returns the intent this metadata references.
intent() - Method in class org.onosproject.net.intent.IntentOperation
Returns the intent to which this operation applied.
intent() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a intent service implementation.
Intent - Class in org.onosproject.net.intent
Abstraction of an application level intent.
Intent() - Constructor for class org.onosproject.net.intent.Intent
Constructor for serializer.
Intent(ApplicationId, Key, Collection<NetworkResource>, int, ResourceGroup) - Constructor for class org.onosproject.net.intent.Intent
Creates a new intent.
INTENT_EVENT - org.onosproject.security.AppPermission.Type
 
INTENT_READ - org.onosproject.security.AppPermission.Type
 
INTENT_TRAFFIC - Static variable in class org.onosproject.ui.GlyphConstants
 
INTENT_WRITE - org.onosproject.security.AppPermission.Type
 
Intent.Builder - Class in org.onosproject.net.intent
Abstract builder for intents.
intentAllowsPartialFailure(Intent) - Static method in class org.onosproject.net.intent.constraint.PartialFailureConstraint
 
IntentBatchDelegate - Interface in org.onosproject.net.intent
Facade for receiving notifications from the intent batch service.
IntentClockService - Interface in org.onosproject.net.intent
Logical clock service that issues per-intent timestamps.
IntentCompilationException - Exception in org.onosproject.net.intent
An exception thrown when a intent compilation fails.
IntentCompilationException() - Constructor for exception org.onosproject.net.intent.IntentCompilationException
 
IntentCompilationException(String) - Constructor for exception org.onosproject.net.intent.IntentCompilationException
 
IntentCompilationException(String, Throwable) - Constructor for exception org.onosproject.net.intent.IntentCompilationException
 
IntentCompiler<T extends Intent> - Interface in org.onosproject.net.intent
Abstraction of a compiler which is capable of taking an intent and translating it to other, potentially installable, intents.
IntentCycleCommand - Class in org.onosproject.cli.net
Installs point-to-point connectivity intents.
IntentCycleCommand() - Constructor for class org.onosproject.cli.net.IntentCycleCommand
 
IntentData - Class in org.onosproject.net.intent
A wrapper class that contains an intents, its state, and other metadata for internal use.
IntentData() - Constructor for class org.onosproject.net.intent.IntentData
 
IntentData(Intent, IntentState, Timestamp) - Constructor for class org.onosproject.net.intent.IntentData
Deprecated.
in 1.11.0
IntentDetailsCommand - Class in org.onosproject.cli.net
Displays details about an Intent in the system.
IntentDetailsCommand() - Constructor for class org.onosproject.cli.net.IntentDetailsCommand
 
IntentEvent - Class in org.onosproject.net.intent
A class to represent an intent related event.
IntentEvent(IntentEvent.Type, Intent) - Constructor for class org.onosproject.net.intent.IntentEvent
Creates an event of a given type and for the specified intent and the current time.
IntentEvent(IntentEvent.Type, Intent, long) - Constructor for class org.onosproject.net.intent.IntentEvent
Creates an event of a given type and for the specified intent and the current time.
IntentEvent.Type - Enum in org.onosproject.net.intent
 
IntentException - Exception in org.onosproject.net.intent
Represents an intent related error.
IntentException() - Constructor for exception org.onosproject.net.intent.IntentException
Constructs an exception with no message and no underlying cause.
IntentException(String) - Constructor for exception org.onosproject.net.intent.IntentException
Constructs an exception with the specified message.
IntentException(String, Throwable) - Constructor for exception org.onosproject.net.intent.IntentException
Constructs an exception with the specified message and the underlying cause.
IntentExtensionService - Interface in org.onosproject.net.intent
Service for extending the capability of intent framework by adding additional compilers or/and installers.
IntentFilter - Class in org.onosproject.net.intent.util
Utility to get flow entries corresponding to specified intent.
IntentFilter(IntentService, FlowRuleService) - Constructor for class org.onosproject.net.intent.util.IntentFilter
Creates an intent filter.
intentId() - Method in class org.onosproject.net.intent.IntentOperation
Returns the identifier of the intent to which this operation applies.
IntentId - Class in org.onosproject.net.intent
Intent identifier suitable as an external key.
IntentIdCompleter - Class in org.onosproject.cli.net.completer
IntentId Completer.
IntentIdCompleter() - Constructor for class org.onosproject.cli.net.completer.IntentIdCompleter
 
intentInstallationContext() - Method in class org.onosproject.net.intent.IntentOperationContext
Retrieves high level Intent installation information.
IntentInstallationContext - Class in org.onosproject.net.intent
Installation context for a high level Intent.
IntentInstallationContext(IntentData, IntentData) - Constructor for class org.onosproject.net.intent.IntentInstallationContext
Creates an Intent installation context by given information.
IntentInstallCoordinator - Interface in org.onosproject.net.intent
Contact point for installers to report progress of intent installation and to update intent-specific status and context appropriately.
IntentInstaller<T extends Intent> - Interface in org.onosproject.net.intent
Manage installation process for specific installable Intents.
IntentInstaller.Direction - Enum in org.onosproject.net.intent
The installation direction.
intentInstallFailed(IntentOperationContext) - Method in interface org.onosproject.net.intent.IntentInstallCoordinator
Handles failed state for an Intent operation context.
intentInstallSuccess(IntentOperationContext) - Method in interface org.onosproject.net.intent.IntentInstallCoordinator
Handles success state for an Intent operation context.
IntentKeyCompleter - Class in org.onosproject.cli.net
Intent Key completer.
IntentKeyCompleter() - Constructor for class org.onosproject.cli.net.IntentKeyCompleter
 
IntentListCompilers - Class in org.onosproject.cli.net
Lists the inventory of intents and their states.
IntentListCompilers() - Constructor for class org.onosproject.cli.net.IntentListCompilers
 
IntentListener - Interface in org.onosproject.net.intent
Listener for intent events.
IntentListInstallers - Class in org.onosproject.cli.net
Lists the installers of intents.
IntentListInstallers() - Constructor for class org.onosproject.cli.net.IntentListInstallers
 
IntentMiniSummary - Class in org.onosproject.net.intent.util
Lists the summary of intents and their states.
IntentMiniSummary() - Constructor for class org.onosproject.net.intent.util.IntentMiniSummary
 
IntentOperation - Class in org.onosproject.net.intent
Abstraction of an intent-related operation, e.g.
IntentOperation(IntentOperation.Type, Intent) - Constructor for class org.onosproject.net.intent.IntentOperation
Creates an intent operation.
IntentOperation.Type - Enum in org.onosproject.net.intent
Operation type.
IntentOperationContext<T extends Intent> - Class in org.onosproject.net.intent
Operation context for installable Intent.
IntentOperationContext(List<T>, List<T>, IntentInstallationContext) - Constructor for class org.onosproject.net.intent.IntentOperationContext
Creates an operation context.
IntentPurgeCommand - Class in org.onosproject.cli.net
Purges all WITHDRAWN intents.
IntentPurgeCommand() - Constructor for class org.onosproject.cli.net.IntentPurgeCommand
 
IntentPushTestCommand - Class in org.onosproject.cli.net
Installs bulk point-to-point connectivity intents between given ingress/egress devices.
IntentPushTestCommand() - Constructor for class org.onosproject.cli.net.IntentPushTestCommand
 
IntentRemoveCommand - Class in org.onosproject.cli.net
Removes an intent.
IntentRemoveCommand() - Constructor for class org.onosproject.cli.net.IntentRemoveCommand
 
INTENTS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
intentsAreEqual(Intent, Intent) - Static method in class org.onosproject.net.intent.IntentUtils
Checks if two intents represent the same value.
IntentsDiagnosisCommand - Class in org.onosproject.cli.net
 
IntentsDiagnosisCommand() - Constructor for class org.onosproject.cli.net.IntentsDiagnosisCommand
 
IntentService - Interface in org.onosproject.net.intent
Service for application submitting or withdrawing their intents.
IntentSetMultimap - Interface in org.onosproject.net.intent
 
IntentsListCommand - Class in org.onosproject.cli.net
Lists the inventory of intents and their states.
IntentsListCommand() - Constructor for class org.onosproject.cli.net.IntentsListCommand
 
IntentState - Enum in org.onosproject.net.intent
Representation of the phases an intent may attain during its lifecycle.
intentsToInstall() - Method in class org.onosproject.net.intent.IntentOperationContext
Retrieves installable Intents to install.
IntentStore - Interface in org.onosproject.net.intent
Manages inventory of end-station intents; not intended for direct use.
IntentStoreDelegate - Interface in org.onosproject.net.intent
Intent store delegate abstraction.
intentsToUninstall() - Method in class org.onosproject.net.intent.IntentOperationContext
Retrieves installable Intents to uninstall.
IntentUtils - Class in org.onosproject.net.intent
Utilities for dealing with intents.
Interface - Class in org.onosproject.net.intf
An Interface maps network configuration information (such as addresses and vlans) to a port in the network.
Interface(String, ConnectPoint, List<InterfaceIpAddress>, MacAddress, VlanId) - Constructor for class org.onosproject.net.intf.Interface
Creates new Interface with the provided configuration.
Interface(String, ConnectPoint, List<InterfaceIpAddress>, MacAddress, VlanId, VlanId, Set<VlanId>, VlanId) - Constructor for class org.onosproject.net.intf.Interface
Creates new Interface with the provided configuration.
INTERFACE_ADDED - org.onosproject.net.intf.InterfaceEvent.Type
Indicates a new interface has been added.
INTERFACE_ID - org.onlab.packet.DHCP6.OptionCode
 
INTERFACE_REMOVED - org.onosproject.net.intf.InterfaceEvent.Type
Indicates an interface has been removed.
INTERFACE_UPDATED - org.onosproject.net.intf.InterfaceEvent.Type
Indicates an interface has been updated.
InterfaceAddCommand - Class in org.onosproject.cli.net
Adds a new interface configuration.
InterfaceAddCommand() - Constructor for class org.onosproject.cli.net.InterfaceAddCommand
 
InterfaceAdminService - Interface in org.onosproject.net.intf
Provides a means to modify the interfaces configuration.
InterfaceConfig - Class in org.onosproject.net.config.basics
Configuration for interfaces.
InterfaceConfig - Interface in org.onosproject.net.behaviour
Means to configure interfaces on devices.
InterfaceConfig() - Constructor for class org.onosproject.net.config.basics.InterfaceConfig
 
InterfaceEvent - Class in org.onosproject.net.intf
Describes an interface event.
InterfaceEvent(InterfaceEvent.Type, Interface) - Constructor for class org.onosproject.net.intf.InterfaceEvent
Creates an interface event with type and subject.
InterfaceEvent(InterfaceEvent.Type, Interface, long) - Constructor for class org.onosproject.net.intf.InterfaceEvent
Creates an interface event with type, subject and time of event.
InterfaceEvent(InterfaceEvent.Type, Interface, Interface) - Constructor for class org.onosproject.net.intf.InterfaceEvent
Creates an interface event with type, subject and previous subject.
InterfaceEvent(InterfaceEvent.Type, Interface, Interface, long) - Constructor for class org.onosproject.net.intf.InterfaceEvent
Creates an interface event with type, subject, previous subject and time.
InterfaceEvent.Type - Enum in org.onosproject.net.intf
 
InterfaceIpAddress - Class in org.onosproject.net.host
Represents a single IP address information on an interface.
InterfaceIpAddress(IpAddress, IpPrefix) - Constructor for class org.onosproject.net.host.InterfaceIpAddress
Constructor for a given IP address and a subnet address.
InterfaceIpAddress(IpAddress, IpPrefix, IpAddress) - Constructor for class org.onosproject.net.host.InterfaceIpAddress
Constructor for a given IP address and a subnet address.
InterfaceIpAddress(IpAddress, IpPrefix, IpAddress, IpAddress) - Constructor for class org.onosproject.net.host.InterfaceIpAddress
Constructor for a given IP address and a subnet address.
InterfaceIpAddress(InterfaceIpAddress) - Constructor for class org.onosproject.net.host.InterfaceIpAddress
Copy constructor.
InterfaceListener - Interface in org.onosproject.net.intf
Listener for interface events.
InterfaceNameCompleter - Class in org.onosproject.cli.net.completer
Completer for interface names.
InterfaceNameCompleter() - Constructor for class org.onosproject.cli.net.completer.InterfaceNameCompleter
 
InterfaceProvisionRequest - Class in org.onosproject.routing
Encapsulates information needed to provision a router interface.
InterfaceRemoveCommand - Class in org.onosproject.cli.net
Removes an interface configuration.
InterfaceRemoveCommand() - Constructor for class org.onosproject.cli.net.InterfaceRemoveCommand
 
interfaces() - Method in class org.onosproject.routing.config.RoutersConfig.Router
Returns the set of interfaces enabled on this router.
interfaces() - Method in class org.onosproject.routing.RouterInfo
Returns the set of interfaces belonging to the router.
INTERFACES_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
InterfaceService - Interface in org.onosproject.net.intf
Service for interacting with interfaces.
InterfacesListCommand - Class in org.onosproject.cli.net
Lists all configured interfaces.
InterfacesListCommand() - Constructor for class org.onosproject.cli.net.InterfacesListCommand
 
InternalConnectivity - Interface in org.onosproject.net.behaviour
Handler behaviour for retrieving internal connectivity information.
InternalConnectivityCommand - Class in org.onosproject.cli.net
 
InternalConnectivityCommand() - Constructor for class org.onosproject.cli.net.InternalConnectivityCommand
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.AbstractGraphPathSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.BellmanFordGraphSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.BreadthFirstSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.DepthFirstSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.DijkstraGraphSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.KShortestPathsSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.SrlgGraphSearch
 
internalSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.SuurballeGraphSearch
 
internalStateVersion() - Method in class org.onosproject.net.intent.IntentData
 
INTERNETWORK_CONTROL - org.onlab.packet.IPPrecedence
 
Interrupted() - Constructor for exception org.onosproject.net.flow.FlowRuleStoreException.Interrupted
 
Interrupted() - Constructor for exception org.onosproject.store.service.ConsistentMapException.Interrupted
 
Interrupted() - Constructor for exception org.onosproject.store.service.DocumentException.Interrupted
 
Interrupted() - Constructor for exception org.onosproject.store.service.StorageException.Interrupted
 
Interrupted() - Constructor for exception org.onosproject.store.service.TransactionException.Interrupted
 
intf() - Method in interface org.onosproject.net.neighbour.NeighbourHandlerRegistration
Gets the interface of the registration.
intf() - Method in class org.onosproject.routing.InterfaceProvisionRequest
Retrieves the interface to be (un)provisioned.
IntMetadataType - Enum in org.onosproject.net.behaviour.inbandtelemetry
Represents a type of INT metadata.
IntObjective - Class in org.onosproject.net.behaviour.inbandtelemetry
Represents a device-level objective to collect INT metadata for packets identified by a traffic selector.
IntObjective.Builder - Class in org.onosproject.net.behaviour.inbandtelemetry
An IntObjective builder.
IntProgrammable - Interface in org.onosproject.net.behaviour.inbandtelemetry
Abstraction of a device implementing In-band Network Telemetry (INT) capabilities.
IntProgrammable.IntFunctionality - Enum in org.onosproject.net.behaviour.inbandtelemetry
INT functionalities that a device can implement.
IntReportConfig - Class in org.onosproject.net.behaviour.inbandtelemetry
Application level configuration of the INT process.
IntReportConfig() - Constructor for class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
 
inUse(VlanId) - Method in interface org.onosproject.net.intf.InterfaceService
Returns true if given vlanId is in use due to configuration on any of the interfaces in the system.
INVALID_GROUP - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
INVALID_METER - org.onosproject.net.meter.MeterFailReason
Invalid meter definition.
invalidate() - Method in class org.onosproject.net.provider.AbstractProviderService
Invalidates this provider service.
InvalidConfigException - Exception in org.onosproject.net.config
Indicates an invalid configuration was supplied by the user.
InvalidConfigException() - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException.InvalidConfigException
InvalidConfigException(String) - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException.InvalidConfigException
InvalidConfigException(String, String, String) - Constructor for exception org.onosproject.net.config.InvalidConfigException
Creates a new invalid config exception about a specific config.
InvalidConfigException(String, String, String, Throwable) - Constructor for exception org.onosproject.net.config.InvalidConfigException
Creates a new invalid config exception about a specific config with an exception regarding the cause of the invalidity.
InvalidConfigException(String, Throwable) - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException.InvalidConfigException
InvalidConfigException(Throwable) - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException.InvalidConfigException
InvalidFieldException - Exception in org.onosproject.net.config
Indicates a field of a configuration was invalid.
InvalidFieldException(String, String) - Constructor for exception org.onosproject.net.config.InvalidFieldException
Creates a new invalid field exception about a given field.
InvalidFieldException(String, Throwable) - Constructor for exception org.onosproject.net.config.InvalidFieldException
Creates a new invalid field exception about a given field.
invocations() - Method in interface org.onosproject.net.packet.PacketProcessorEntry
Returns the number of invocations.
invokeAll(Collection<? extends Callable<T>>) - Method in class org.onlab.junit.NullScheduledExecutor
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.onlab.util.SharedScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.onlab.junit.NullScheduledExecutor
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.onlab.util.SharedScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
 
IOAM - org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.TelemetrySpec
Embeds telemetry metadata according to the OAM specification.
ip() - Method in interface org.onosproject.cluster.Node
Returns the IP address of the controller instance.
ip() - Method in class org.onosproject.net.behaviour.ControllerInfo
Exposes the ip address of the controller.
ip() - Method in class org.onosproject.net.flow.criteria.ArpPaCriterion
Gets the Ip4 Address to match.
ip() - Method in class org.onosproject.net.flow.criteria.IPCriterion
Gets the IP prefix to match.
ip() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpIPInstruction
 
ip() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPInstruction
 
ip() - Method in class org.onosproject.routing.NextHop
Returns the next hop's IP address.
ip() - Method in class org.onosproject.ui.model.topo.UiClusterMember
Returns the IP address of the cluster member.
ip(boolean) - Method in class org.onosproject.cluster.DefaultControllerNode
 
ip(boolean) - Method in interface org.onosproject.cluster.Node
Returns the IP address of the controller instance.
IP - Class in org.onlab.packet
Implements IP packet format.
IP - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
IP() - Constructor for class org.onlab.packet.IP
 
IP_DSCP - org.onosproject.net.flow.criteria.Criterion.Type
IP DSCP (6 bits in ToS field).
IP_DSCP - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
IP DSCP operation modification.
IP_ECN - org.onosproject.net.flow.criteria.Criterion.Type
IP ECN (2 bits in ToS field).
IP_PROTO - org.onosproject.net.flow.criteria.Criterion.Type
IP protocol.
Ip4Address - Class in org.onlab.packet
A class representing an IPv4 address.
Ip4AddressSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for Ip4Address.
Ip4AddressSerializer() - Constructor for class org.onosproject.store.serializers.Ip4AddressSerializer
Creates Ip4Address serializer instance.
Ip4Prefix - Class in org.onlab.packet
The class representing an IPv4 network address.
Ip4PrefixSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for Ip4Prefix.
Ip4PrefixSerializer() - Constructor for class org.onosproject.store.serializers.Ip4PrefixSerializer
Creates Ip4Prefix serializer instance.
Ip6Address - Class in org.onlab.packet
A class representing an IPv6 address.
Ip6AddressSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for Ip6Address.
Ip6AddressSerializer() - Constructor for class org.onosproject.store.serializers.Ip6AddressSerializer
Creates Ip6Address serializer instance.
Ip6Prefix - Class in org.onlab.packet
The class representing an IPv6 network address.
Ip6PrefixSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for Ip6Prefix.
Ip6PrefixSerializer() - Constructor for class org.onosproject.store.serializers.Ip6PrefixSerializer
Creates Ip6Prefix serializer instance.
IPacket - Interface in org.onlab.packet
Packet Interface.
ipAddress - Variable in class org.onlab.packet.RIPV2Entry
 
ipAddress() - Method in class org.onosproject.dhcp.IpAssignment
Returns the IP Address of the IP assignment.
ipAddress() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
Returns the IP address of the attachment.
ipAddress() - Method in class org.onosproject.net.host.DefaultHostDescription
 
ipAddress() - Method in interface org.onosproject.net.host.HostDescription
Returns the IP address associated with this host's MAC.
ipAddress() - Method in class org.onosproject.net.host.InterfaceIpAddress
Gets the IP address.
ipAddress() - Method in class org.onosproject.net.IpElementId
Returns the ip address.
ipAddress(Ip4Address) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
IpAddress - Class in org.onlab.packet
A class representing an IP address.
IpAddress() - Constructor for class org.onlab.packet.IpAddress
Default constructor for Kryo serialization.
IpAddress(IpAddress.Version, byte[]) - Constructor for class org.onlab.packet.IpAddress
Constructor for given IP address version and address octets.
IpAddress.Version - Enum in org.onlab.packet
 
ipAddresses() - Method in class org.onosproject.net.config.basics.BasicHostConfig
Returns IP addresses of the host.
ipAddresses() - Method in class org.onosproject.net.DefaultHost
Returns an unmodifiable set of IP addresses currently bound to the host MAC address.
ipAddresses() - Method in interface org.onosproject.net.Host
Returns set of IP addresses currently bound to the host MAC address.
ipAddressesList() - Method in class org.onosproject.net.intf.Interface
Retrieves a list of IP addresses that are assigned to the interface in the order that they were configured.
IpAddressSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for IpAddress.
IpAddressSerializer() - Constructor for class org.onosproject.store.serializers.IpAddressSerializer
Creates IpAddress serializer instance.
IpAssignment - Class in org.onosproject.dhcp
Stores the MAC ID to IP Address mapping details.
IpAssignment.AssignmentStatus - Enum in org.onosproject.dhcp
 
IpAssignment.Builder - Class in org.onosproject.dhcp
IPAssignment Builder.
IPCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IP address criterion.
ipDscp() - Method in class org.onosproject.net.flow.criteria.IPDscpCriterion
Gets the IP DSCP value to match.
IPDscpCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IP DSCP (Differentiated Services Code Point) criterion (6 bits).
ipEcn() - Method in class org.onosproject.net.flow.criteria.IPEcnCriterion
Gets the IP ECN value to match.
IPEcnCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IP ECN (Explicit Congestion Notification) criterion (2 bits).
ipElement(IpAddress) - Static method in class org.onosproject.net.IpElementId
Create a IP Element ID.
ipElementId() - Method in class org.onosproject.net.ConnectPoint
Returns the identifier of the infrastructure device if the connection point belongs to a network element which is indeed an ip of pcc client identifier.
IpElementId - Class in org.onosproject.net
Represent for a Element ID using ip address.
IPoE - org.onosproject.net.behaviour.BngProgrammable.Attachment.AttachmentType
IPoE attachment.
ipPrecedence(IPPrecedence) - Method in class org.onosproject.net.behaviour.BandwidthProfileAction.Builder
Sets the IP precedence of this builder.
IPPrecedence - Enum in org.onlab.packet
Represents the deprecated IPv4 IP precedence.
IpPrefix - Class in org.onlab.packet
A class representing an IP prefix.
IpPrefix() - Constructor for class org.onlab.packet.IpPrefix
Default constructor for Kryo serialization.
IpPrefix(IpAddress, int) - Constructor for class org.onlab.packet.IpPrefix
Constructor for given IP address, and a prefix length.
IpPrefixSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for IpPrefix.
IpPrefixSerializer() - Constructor for class org.onosproject.store.serializers.IpPrefixSerializer
Creates IpPrefix serializer instance.
IpProtocol - Enum in org.onosproject.cli.net
Known protocol values for IP protocol field that can be supplied to the CLI.
IpProtocolCompleter - Class in org.onosproject.cli.net
IP protocol completer.
IpProtocolCompleter() - Constructor for class org.onosproject.cli.net.IpProtocolCompleter
 
IPProtocolCriterion - Class in org.onosproject.net.flow.criteria
Implementation of Internet Protocol Number criterion (8 bits unsigned) integer.
IPS - org.onosproject.net.Device.Type
 
IPS - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
ipTunnelEndpoint(IpAddress) - Static method in class org.onosproject.net.behaviour.TunnelEndPoints
Returns a tunnel endpoint with supplied IP address.
IPv4 - Class in org.onlab.packet
Implements IPv4 packet format.
IPv4() - Constructor for class org.onlab.packet.IPv4
Default constructor that sets the version to 4.
IPV4 - org.onlab.packet.EthType.EtherType
 
IPV4 - org.onosproject.cli.net.EthType
IPV4.
IPV4_ADDRSZ - Static variable in class org.onlab.packet.bmp.BmpPeer
 
IPV4_DST - org.onosproject.net.flow.criteria.Criterion.Type
IPv4 destination address.
IPV4_DST - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
IPv4 dst modification.
IPV4_LINK_LOCAL_PREFIX - Static variable in class org.onlab.packet.IpPrefix
An IpPrefix that contains all IPv4 link local addresses.
IPV4_MULTICAST - Static variable in class org.onlab.packet.MacAddress
IPv4 multicast MAC address.
IPV4_MULTICAST_MASK - Static variable in class org.onlab.packet.MacAddress
IPv4 multicast MAC mask.
IPV4_MULTICAST_PREFIX - Static variable in class org.onlab.packet.IpPrefix
An IpPrefix that contains all IPv4 multicast addresses.
IPV4_SRC - org.onosproject.net.flow.criteria.Criterion.Type
IPv4 source address.
IPV4_SRC - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
IPv4 src modification.
IPv6 - Class in org.onlab.packet
Implements IPv6 packet format.
IPv6() - Constructor for class org.onlab.packet.IPv6
Default constructor that sets the version to 6.
IPV6 - org.onlab.packet.EthType.EtherType
 
IPV6 - org.onosproject.cli.net.EthType
IPV6.
IPV6_ADDRSZ - Static variable in class org.onlab.packet.bmp.BmpPeer
 
IPV6_DST - org.onosproject.net.flow.criteria.Criterion.Type
IPv6 destination address.
IPV6_DST - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
IPv6 dst modification.
IPV6_EXTHDR - org.onosproject.net.flow.criteria.Criterion.Type
IPv6 Extension Header pseudo-field.
IPV6_FLABEL - org.onosproject.net.flow.criteria.Criterion.Type
IPv6 Flow Label.
IPV6_FLABEL - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
IPv6 flow label modification.
IPV6_LINK_LOCAL_PREFIX - Static variable in class org.onlab.packet.IpPrefix
An IpPrefix that contains all IPv6 link local addresses.
IPV6_MULTICAST - Static variable in class org.onlab.packet.MacAddress
IPv6 multicast MAC address.
IPV6_MULTICAST_MASK - Static variable in class org.onlab.packet.MacAddress
IPv6 multicast MAC mask.
IPV6_MULTICAST_PREFIX - Static variable in class org.onlab.packet.IpPrefix
An IpPrefix that contains all IPv6 multicast addresses.
IPV6_ND_SLL - org.onosproject.net.flow.criteria.Criterion.Type
Source link-layer for ND.
IPV6_ND_TARGET - org.onosproject.net.flow.criteria.Criterion.Type
Target address for ND.
IPV6_ND_TLL - org.onosproject.net.flow.criteria.Criterion.Type
Target link-layer for ND.
IPV6_OPT_ERR - org.onosproject.cli.net.Icmp6Code
Unrecognized IPv6 option encountered.
IPV6_OPT_ERR - Static variable in class org.onlab.packet.ICMP6
Unrecognized IPv6 option encountered.
IPV6_SRC - org.onosproject.net.flow.criteria.Criterion.Type
IPv6 source address.
IPV6_SRC - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
IPv6 src modification.
IPv6ExthdrFlagsCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IPv6 Extension Header pseudo-field criterion (16 bits).
IPv6FlowLabelCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IPv6 Flow Label (RFC 6437) criterion (20 bits unsigned integer).
IPv6NDLinkLayerAddressCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IPv6 Neighbor Discovery link-layer address criterion.
IPv6NDTargetAddressCriterion - Class in org.onosproject.net.flow.criteria
Implementation of IPv6 Neighbor Discovery target address criterion.
is(Class<B>) - Method in class org.onosproject.net.AbstractProjectableModel
 
is(Class<B>) - Method in interface org.onosproject.net.driver.Projectable
Returns true if this entity is capable of being projected as the specified class.
is(Class<B>) - Method in interface org.onosproject.net.utils.ForwardingDevice
 
IS_BIDIRECTIONAL - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
IS_DURABLE - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
IS_METERED - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
isAccess() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
Check if this UPF interface is for packets traveling from UEs.
isActive() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the active flag set.
isActive() - Method in enum org.onosproject.cluster.ControllerNode.State
Indicates whether the state represents node which is active or ready.
isActive() - Method in class org.onosproject.ui.UiTopo2Overlay
Returns true if this overlay is currently active.
isActive() - Method in class org.onosproject.ui.UiTopoOverlay
Returns true if this overlay is currently active.
isActive(String) - Method in class org.onosproject.common.app.ApplicationArchive
Indicates whether the app was marked as active by checking for token file.
isAdded(NodeId) - Method in class org.onosproject.cluster.PartitionDiff
Returns if the specified node is introduced in the new value.
isAggregatable() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the aggregatable flag set.
isAllowed() - Method in class org.onosproject.net.config.basics.AllowedEntityConfig
Indicates whether the element is allowed for admission into the control domain.
isAllowed(Boolean) - Method in class org.onosproject.net.config.basics.AllowedEntityConfig
Specifies whether the element is to be allowed for admission into the control domain.
isAncestorOf(DocumentPath) - Method in class org.onosproject.store.service.DocumentPath
Returns if the specified path belongs to a direct ancestor of the node pointed at by this path.
isAncillary() - Method in class org.onosproject.net.provider.ProviderId
Indicates whether this identifier designates an ancillary providers.
isAppSecured(ApplicationId) - Static method in class org.onosproject.security.SecurityUtil
 
isAscii() - Method in class org.onlab.util.ImmutableByteSequence
Checks if the content can be interpreted as an ASCII printable string.
isAuditing() - Method in interface org.onosproject.security.AuditService
Returns true if auditing is enabled.
isAvailable() - Method in interface org.onosproject.cluster.ClusterMetadataProvider
Tells if this provider is currently available and therefore can provide ClusterMetadata.
isAvailable() - Method in interface org.onosproject.net.device.DeviceHandshaker
Checks the availability of the device.
isAvailable(DeviceId) - Method in interface org.onosproject.net.device.DeviceProvider
Checks the availability of the device from the provider perspective.
isAvailable(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Indicates whether or not the device is presently online and available.
isAvailable(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
isAvailable(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Indicates whether the specified device is available/online.
isAvailable(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
isAvailable(Resource) - Method in interface org.onosproject.net.intent.ResourceContext
Returns the availability of the specified resource.
isAvailable(Resource) - Method in interface org.onosproject.net.resource.ResourceQueryService
Returns the availability of the specified resource.
isAvailable(Resource) - Method in interface org.onosproject.net.resource.ResourceStore
Returns the availability of the specified resource.
isBidirectional() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns if link is bidirectional in the network model or not.
isBidirectional() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
Returns the directionality of the intent.
isBidirectional() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
Returns the directionality of the intent.
isBidirectional() - Method in class org.onosproject.net.intent.OpticalOduIntent
Returns the directionality of the intent.
isBidirectional() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
isBidirectional(Boolean) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets durability for this link.
isBlocked() - Method in class org.onlab.util.BlockingAwareFuture
Returns a boolean indicating whether the future is blocked.
isBoolean(ObjectNode, String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid boolean value.
isBoolean(String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid boolean value.
isBroadcast() - Method in class org.onlab.packet.Ethernet
 
isBroadcast() - Method in class org.onlab.packet.MacAddress
Returns true if the MAC address is the broadcast address.
isBroadcastPoint(ConnectPoint) - Method in class org.onosproject.common.DefaultTopology
Indicates whether the given point is part of a broadcast set.
isBroadcastPoint(Topology, ConnectPoint) - Method in interface org.onosproject.net.topology.TopologyService
Indicates whether broadcast is allowed for traffic received on the specified connection point.
isBroadcastPoint(Topology, ConnectPoint) - Method in interface org.onosproject.net.topology.TopologyStore
Indicates whether broadcast is allowed for traffic received on the given connection point.
isBurst() - Method in class org.onosproject.net.meter.DefaultMeter
 
isBurst() - Method in class org.onosproject.net.meter.DefaultMeterRequest
 
isBurst() - Method in interface org.onosproject.net.meter.Meter
Signals whether this meter applies to bursts only.
isBurst() - Method in interface org.onosproject.net.meter.MeterRequest
Signals whether this meter applies to bursts only.
isBurstSupported() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
isBurstSupported() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns if burst size is available.
isClassOf(Class<?>) - Method in class org.onosproject.net.resource.ResourceConsumerId
Checks if the consumer is an instance of given class.
isCollecting() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the collecting flag set.
isColorAware() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
isColorAware() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
Indicates if this policer is aware of the marking indication in the ethernet frames.
isComplete() - Method in class org.onlab.util.CountDownCompleter
Returns if this instance has completed.
isComplete() - Method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
 
isConfigured(ConnectPoint) - Method in interface org.onosproject.net.intf.InterfaceService
Returns true if given connectPoint has an IP address or vlan configured on any of its interfaces.
isConnectedToPeer(IpAddress) - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
Examines if BGP peer is connected.
isConnectPoint(ObjectNode, String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid connect point string.
isConnectPoint(String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid connect point string.
isConstantTable() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns true if the table is populated with static entries that cannot be modified by the control plane at runtime.
isCore() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
Check if this UPF interface is for packets traveling towards UEs.
isDbufReceiver() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
Check if this UPF interface is for receiving buffered packets as they are released from the dbuf buffering device.
isDebugEnabled() - Method in class org.onlab.junit.LoggerAdapter
 
isDebugEnabled(Marker) - Method in class org.onlab.junit.LoggerAdapter
 
isDecimal(ObjectNode, String, Config.FieldPresence, double...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid decimal number.
isDecimal(String, Config.FieldPresence, double...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid decimal number.
isDefault() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the default flag set.
isDefault() - Method in class org.onosproject.ui.model.topo.UiTopoLayoutId
Returns true if this is the identifier for the default layout.
isDefaultAction() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
Returns true if this table entry contains the default action for this table, a.k.a.
isDefaultAvailable() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
isDefaultAvailable() - Method in interface org.onosproject.net.device.DeviceDescription
Return whether device should be made available by default.
isDefaultConfig() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
Check if the config represents a reset operation.
isDescendentOf(DocumentPath) - Method in class org.onosproject.store.service.DocumentPath
Returns if the specified path is belongs to a subtree rooted this path.
isDeviceDevice() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns true if this identifier represents a device-device (infrastructure) link.
isDistributing() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the distributing flag set.
isDropped() - Method in class org.onosproject.net.PipelineTraceableHitChain
Return whether or not the packet has been dropped by the pipeline.
isDurable() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns if link is durable in the network model or not.
isDurable(Boolean) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets durability for this link.
isEdgePoint(ConnectPoint) - Method in interface org.onosproject.net.edge.EdgePortService
Indicates whether or not the specified connection point is an edge point.
isEmpty() - Method in class org.onlab.graph.Heap
Returns true if there are no items in the heap.
isEmpty() - Method in class org.onlab.util.ExtendedSet
 
isEmpty() - Method in class org.onlab.util.UnmodifiableDeque
 
isEmpty() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
isEmpty() - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
isEmpty() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
isEmpty() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
isEmpty() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
isEmpty() - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
isEmpty() - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Returns a boolean indicating whether the map is empty.
isEmpty() - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns true if the map is empty.
isEmpty() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns if this multimap contains no key-value pairs.
isEmpty() - Method in interface org.onosproject.store.service.AsyncDistributedSet
Returns if the set is empty.
isEmpty() - Method in interface org.onosproject.store.service.AtomicCounterMap
If the map is empty, returns true, otherwise false.
isEmpty() - Method in interface org.onosproject.store.service.ConsistentMap
Returns true if the map is empty.
isEmpty() - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns if this multimap contains no key-value pairs.
isEmpty() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Returns true if this map is empty.
isEnabled() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription
Returns administrative state.
isEnabled() - Method in class org.onosproject.net.DefaultPort
 
isEnabled() - Method in class org.onosproject.net.device.DefaultPortDescription
 
isEnabled() - Method in interface org.onosproject.net.device.PortDescription
Indicates whether or not the port is up and active.
isEnabled() - Method in interface org.onosproject.net.Port
Indicates whether or not the port is currently up and active.
isEnabled() - Method in class org.onosproject.net.utils.ForwardingPort
 
isEnabled(boolean) - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
Sets enabled state.
isEnabled(VlanId) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Obtains the status of a VLAN on a device.
isEnabled(PortNumber) - Method in interface org.onosproject.net.behaviour.PortAdmin
Retrieves the information about the administrative state of a port.
isEqual(Annotations, Annotations) - Static method in class org.onosproject.net.AnnotationsUtil
 
isErrorEnabled() - Method in class org.onlab.junit.LoggerAdapter
 
isErrorEnabled(Marker) - Method in class org.onlab.junit.LoggerAdapter
 
isExpected() - Method in class org.onosproject.net.DefaultLink
 
isExpected() - Method in class org.onosproject.net.link.DefaultLinkDescription
 
isExpected() - Method in interface org.onosproject.net.Link
Indicates if the link was created from a predefined configuration.
isExpected() - Method in interface org.onosproject.net.link.LinkDescription
Returns true if the link is expected, false otherwise.
isExpected(boolean) - Method in class org.onosproject.net.DefaultLink.Builder
Sets the expected flag to be used by the builder.
isExpired() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the expired flag set.
isForwardEdge(AbstractGraphPathSearch.DefaultResult, E) - Method in class org.onlab.graph.DepthFirstSearch
Determines whether the specified edge is a forward edge using the accumulated set of parent edges for each vertex.
isFullyStarted(List<String>) - Method in interface org.onosproject.cluster.ComponentsMonitorService
Checks if all given OSGi features are ready.
isGlobal() - Method in class org.onosproject.net.meter.MeterScope
Global scope or not.
isGlyph() - Method in class org.onosproject.ui.topo.NodeBadge
Returns true if the text for this badge designates a glyph ID.
isGratuitous() - Method in class org.onlab.packet.ARP
 
isGreaterThan(T) - Method in interface org.onlab.util.RichComparable
Compares if this object is greater than the specified object.
isGroupStateAddedFirstTime() - Method in class org.onosproject.net.group.DefaultGroup
 
isGroupStateAddedFirstTime() - Method in interface org.onosproject.net.group.StoredGroupEntry
Returns the isGroupStateAddedFirstTime value.
isHandled() - Method in class org.onosproject.net.packet.DefaultPacketContext
 
isHandled() - Method in interface org.onosproject.net.packet.PacketContext
Indicates whether the outbound packet is handled, i.e.
isHostDevice() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns true if this identifier represents a host-device (edge) link.
isIncluded(Port) - Method in class org.onosproject.cli.net.DevicePortsListCommand
 
isInclusive() - Method in class org.onosproject.net.intent.constraint.LinkTypeConstraint
Indicates if the constraint is inclusive or exclusive.
isInclusive() - Method in class org.onosproject.net.intent.constraint.TierConstraint
Indicates if the constraint is inclusive or exclusive.
isInfoEnabled() - Method in class org.onlab.junit.LoggerAdapter
 
isInfoEnabled(Marker) - Method in class org.onlab.junit.LoggerAdapter
 
isInfrastructure(ConnectPoint) - Method in class org.onosproject.common.DefaultTopology
Indicates whether the given point is an infrastructure link end-point.
isInfrastructure(Topology, ConnectPoint) - Method in interface org.onosproject.net.topology.TopologyService
Indicates whether the specified connection point is part of the network infrastructure or part of network edge.
isInfrastructure(Topology, ConnectPoint) - Method in interface org.onosproject.net.topology.TopologyStore
Indicates whether the given connect point is part of the network fabric.
isInstallable() - Method in class org.onosproject.net.domain.DomainIntent
 
isInstallable() - Method in class org.onosproject.net.intent.FlowObjectiveIntent
 
isInstallable() - Method in class org.onosproject.net.intent.FlowRuleIntent
 
isInstallable() - Method in class org.onosproject.net.intent.Intent
Indicates whether or not the intent is installable.
isInstallable() - Method in class org.onosproject.net.intent.ProtectionEndpointIntent
 
isIntegralNumber(ObjectNode, String, Config.FieldPresence, long...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid integer.
isIntegralNumber(String, Config.FieldPresence, long...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid integer.
isIp4() - Method in class org.onlab.packet.IpAddress
Tests whether the IP version of this address is IPv4.
isIp4() - Method in class org.onlab.packet.IpPrefix
Tests whether the IP version of this prefix is IPv4.
isIp6() - Method in class org.onlab.packet.IpAddress
Tests whether the IP version of this address is IPv6.
isIp6() - Method in class org.onlab.packet.IpPrefix
Tests whether the IP version of this prefix is IPv6.
isIpAddress(ObjectNode, String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid IP address.
isIpAddress(String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid IP address.
isIpPrefix(ObjectNode, String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid IP prefix.
isIpPrefix(String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid IP prefix.
isLatest(Topology) - Method in interface org.onosproject.net.topology.TopologyService
Indicates whether the specified topology is the latest or not.
isLatest(Topology) - Method in interface org.onosproject.net.topology.TopologyStore
Indicates whether the topology is the latest.
isLessThan(T) - Method in interface org.onlab.util.RichComparable
Compares if this object is less than the specified object.
isLinkLocal() - Method in class org.onlab.packet.IpAddress
Check if this IP address is a link-local address.
isLinkLocalAddress(byte[]) - Static method in class org.onlab.packet.IPv6
According to the RFC 4291, an IPv6 link local address is an IPv6 unicast address that can be automatically configured on any interface using the link-local prefix FE80::/10 (1111 1110 10) and the interface identifier in the modified EUI-64 format.
isList() - Method in class org.onosproject.net.config.ConfigFactory
Indicates whether the configuration is a list and should be backed by a JSON array rather than JSON object.
isLive() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState
Returns liveness state of this endpoint.
isLldp() - Method in class org.onlab.packet.MacAddress
Returns true if this MAC address is used by link layer discovery protocol.
isLocal(Key) - Method in interface org.onosproject.net.intent.IntentService
Signifies whether the local node is responsible for processing the given intent key.
isLocalActive() - Method in interface org.onosproject.upgrade.UpgradeService
Returns whether the local node is active.
isLocalMaster(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Returns true if the local controller is the Master for the specified deviceId.
isLocalUpgraded() - Method in interface org.onosproject.upgrade.UpgradeService
Returns whether the local node is an upgraded node.
isLogical() - Method in class org.onosproject.net.PortNumber
Indicates whether or not this port number is a reserved logical one or whether it corresponds to a normal physical port of a device or NIC.
isMacAddress(ObjectNode, String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid MAC address.
isMacAddress(String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid MAC address.
isMACAddress(String) - Static method in class org.onlab.packet.Ethernet
Checks to see if a string is a valid MAC address.
isMaster(Key) - Method in interface org.onosproject.net.intent.IntentStore
Checks to see whether the calling instance is the master for processing this intent, or more specifically, the key contained in this intent.
isMetered() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns if link is metered in the network model or not.
isMetered(Boolean) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets metered flag for this link.
isMine(K, Function<K, Long>) - Method in interface org.onosproject.net.intent.WorkPartitionService
Returns whether a given identifier maps to a partition owned by this instance.
isModifyConfig() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
Check if the config represents a modify operation.
isMulticast() - Method in class org.onlab.packet.Ethernet
 
isMulticast() - Method in class org.onlab.packet.IpAddress
Check if this IP address is a multicast address.
isMulticast() - Method in class org.onlab.packet.IpPrefix
Check if this IP prefix is a multicast prefix.
isMulticast() - Method in class org.onlab.packet.MacAddress
Returns true if the MAC address is the multicast address.
isNegative() - Method in class org.onlab.graph.ScalarWeight
 
isNegative() - Method in interface org.onlab.graph.Weight
Returns true if the weight is negative (means that aggregated path cost will decrease if we add weighted subject to it).
isNewerThan(Timestamp) - Method in interface org.onosproject.store.Timestamp
Tests if this timestamp is newer than the specified timestamp.
isNullOrEmpty(Collection<?>) - Static method in class org.onlab.util.Tools
Returns true if the collection is null or is empty.
isNumber(ObjectNode, String, Config.FieldPresence, long...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid number.
isNumber(String, Config.FieldPresence, long...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid number.
ISOLATE - org.onosproject.store.service.RevisionType
A distributed primitive that is initialized from the state of the previous revision and thereafter diverges.
isOlderThan(Timestamp) - Method in interface org.onosproject.store.Timestamp
Tests if this timestamp is older than the specified timestamp.
isOnos() - Method in class org.onlab.packet.MacAddress
Returns true if the Organizationally Unique Identifier (OUI) of this MAC address matches ONOS OUI.
isOpen() - Method in interface org.onosproject.store.service.TransactionContext
Returns if this transaction context is open.
isOrigin() - Method in class org.onosproject.ui.topo.LayoutLocation
Returns true if the coordinates indicate the origin (0, 0) of the coordinate system; false otherwise.
isOspfEnabled() - Method in class org.onosproject.routing.config.RoutersConfig.Router
Returns whether OSPF is enabled on this router.
isPad() - Method in class org.onlab.packet.Ethernet
Pad this packet to 60 bytes minimum, filling with zeros?
isPendingContextsEmpty() - Method in class org.onosproject.net.intent.IntentInstallationContext
Check if pending context is empty.
isPermanent() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
isPermanent() - Method in interface org.onosproject.net.flow.FlowRule
Returns whether the flow is permanent i.e.
isPipeconfSet(PiPipeconf) - Method in interface org.onosproject.net.behaviour.PiPipelineProgrammable
Probes the device to verify that the given pipeconf is the one currently configured.
isPropertyEnabled(Dictionary<?, ?>, String) - Static method in class org.onlab.util.Tools
Check property name is defined and set to true.
isPropertyEnabled(Dictionary<?, ?>, String, boolean) - Static method in class org.onlab.util.Tools
Check property name is defined as set to true.
isPurgeOnDisconnectionConfigured() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns if the device purgeOnDisconnection flag for this device has been explicitly configured.
isRateLimited() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
Indicates whether a rate limit has been set on the interface.
isRateLimited() - Method in interface org.onosproject.net.device.DeviceInterfaceDescription
Indicates whether a rate limit has been set on the interface.
isReachable() - Method in interface org.onosproject.net.device.DeviceHandshaker
Returns true if this node is presumed to be able to send messages and receive replies from the device.
isReachable(DeviceId) - Method in interface org.onosproject.net.device.DeviceProvider
Checks the reachability (connectivity) of a device from this provider.
isReady() - Method in class org.onlab.util.AbstractAccumulator
 
isReady() - Method in interface org.onlab.util.Accumulator
Indicates whether the accumulator is ready to process items.
isReady() - Method in enum org.onosproject.cluster.ControllerNode.State
Indicates whether the state represents a node which is ready.
isRegionDevice() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns true if this identifier represents a region-device link.
isRegionRegion() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns true if this identifier represents a region-region link.
isRelevant(E) - Method in interface org.onosproject.event.EventFilter
Indicates whether the specified event is of interest or not.
isRelevant(UiModelEvent) - Method in class org.onosproject.ui.model.topo.UiRegion
Determins whether the specified event is relevant to the view constrained to this region.
isRemoved() - Method in class org.onosproject.net.device.DefaultPortDescription
 
isRemoved() - Method in interface org.onosproject.net.device.PortDescription
Indicates whether or not the port was removed.
isRemoved(boolean) - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
Sets removed state.
isRemoved(String) - Method in class org.onosproject.net.DefaultAnnotations
 
isRemoved(String) - Method in interface org.onosproject.net.SparseAnnotations
Indicates whether the specified key has been tagged as removed.
isRemoved(NodeId) - Method in class org.onosproject.cluster.PartitionDiff
Returns if the specified node is removed in the new value.
isRoot() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns true if this is the root (default) region.
isRoot() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns true if this layout instance is at the top of the hierarchy tree.
isRouter() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets whether this neighbour message context involves a router.
isSbit() - Method in class org.onlab.packet.IGMPQuery
Is the S flag set? Telling adjacent routers to suppress normal timer updates.
isSecured(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
Returns true if security policy has been enforced to specified application.
isSecurityModeEnabled() - Static method in class org.onosproject.security.SecurityUtil
 
isSelfAssigned() - Method in class org.onlab.packet.IpAddress
Check if this IP address is self-assigned.
isSet() - Method in class org.onosproject.cfg.ConfigProperty
Indicates whether the property is set or whether it assumes its default value.
isShutdown() - Method in class org.onlab.junit.NullScheduledExecutor
 
isShutdown() - Method in class org.onlab.util.PredictableExecutor
 
isShutdown() - Method in class org.onlab.util.SharedScheduledExecutorService
 
isStatsSupported() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
isStatsSupported() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns if statistics collection is available.
isString(ObjectNode, String, Config.FieldPresence, String...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field on a particular node holds a valid string value.
isString(String, Config.FieldPresence, String...) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid string value.
isSubTypeOf(Class<?>) - Method in class org.onosproject.net.resource.ContinuousResource
 
isSubTypeOf(Class<?>) - Method in class org.onosproject.net.resource.DiscreteResource
 
isSubTypeOf(Class<?>) - Method in interface org.onosproject.net.resource.Resource
Checks if the type of this instance is the sub-type of the specified type.
isSuccess() - Method in interface org.onosproject.net.flow.BatchOperationResult
Returns whether the operation was successful.
isSuccess() - Method in class org.onosproject.net.flow.CompletedBatchOperation
 
IssuCommand - Class in org.onosproject.cli
Commands for managing upgrades.
IssuCommand() - Constructor for class org.onosproject.cli.IssuCommand
 
issueToken(String) - Method in interface org.onosproject.ui.UiTokenService
Issues a session token.
isSync() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the synchronization flag set.
isTerminated() - Method in class org.onlab.junit.NullScheduledExecutor
 
isTerminated() - Method in class org.onlab.util.PredictableExecutor
 
isTerminated() - Method in class org.onlab.util.SharedScheduledExecutorService
 
isTimeout() - Method in class org.onlab.packet.lacp.LacpState
Checks if this state has the timeout flag set.
isTimestampAvailable(DeviceId) - Method in interface org.onosproject.net.device.DeviceClockService
Checks if this service can issue Timestamp for specified device.
isTokenValid(UiSessionToken) - Method in interface org.onosproject.ui.UiTokenService
Returns true if the specified token is currently in the distributed map of valid UI session tokens.
isTpPort(ObjectNode, String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field of a particular node holds a valid transport layer port.
isTpPort(String, Config.FieldPresence) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field holds a valid transport layer port.
isTraceEnabled() - Method in class org.onlab.junit.LoggerAdapter
 
isTraceEnabled(Marker) - Method in class org.onlab.junit.LoggerAdapter
 
isTruncated - Variable in class org.onlab.packet.IPv4
 
isTruncated() - Method in class org.onlab.packet.IPv4
 
isTypeConfigured() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns if the link type is configured.
isTypeOf(Class<?>) - Method in class org.onosproject.net.resource.ContinuousResource
 
isTypeOf(Class<?>) - Method in class org.onosproject.net.resource.DiscreteResource
 
isTypeOf(Class<?>) - Method in interface org.onosproject.net.resource.Resource
Checks if the type of this instance is the specified type.
isUpdateAcceptable(IntentData, IntentData) - Static method in class org.onosproject.net.intent.IntentData
Determines whether an intent data update is allowed.
isUpgrading() - Method in interface org.onosproject.upgrade.UpgradeService
Returns whether an upgrade is in progress.
isUseMetered() - Method in class org.onosproject.net.intent.constraint.MeteredConstraint
Indicates if the constraint is metered or not.
isValid() - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
 
isValid() - Method in class org.onosproject.net.config.basics.BandwidthCapacity
 
isValid() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
 
isValid() - Method in class org.onosproject.net.config.basics.BasicElementConfig
 
isValid() - Method in class org.onosproject.net.config.basics.BasicHostConfig
 
isValid() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
 
isValid() - Method in class org.onosproject.net.config.basics.BasicRegionConfig
 
isValid() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
 
isValid() - Method in class org.onosproject.net.config.basics.DeviceAnnotationConfig
 
isValid() - Method in class org.onosproject.net.config.basics.HostAnnotationConfig
 
isValid() - Method in class org.onosproject.net.config.basics.HostLearningConfig
 
isValid() - Method in class org.onosproject.net.config.basics.InterfaceConfig
 
isValid() - Method in class org.onosproject.net.config.basics.McastConfig
 
isValid() - Method in class org.onosproject.net.config.basics.PortAnnotationConfig
 
isValid() - Method in class org.onosproject.net.config.basics.PortDescriptionsConfig
 
isValid() - Method in class org.onosproject.net.config.Config
Indicates whether or not the backing JSON node contains valid data.
isValid() - Method in class org.onosproject.net.config.inject.DeviceInjectionConfig
 
isValid() - Method in class org.onosproject.net.pi.runtime.data.PiHeader
Return whether the header is valid.
isValid() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
Returns true if this header is valid, false otherwise.
isValid() - Method in class org.onosproject.net.statistic.DefaultLoad
 
isValid() - Method in interface org.onosproject.net.statistic.Load
Indicates whether this load was built on valid values.
isValid() - Method in class org.onosproject.routing.config.RouterConfig
Deprecated.
 
isValid() - Method in class org.onosproject.routing.config.RoutersConfig
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.BandwidthConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.BooleanConstraint
Returns true if the specified link satisfies the constraint.
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.EncapsulationConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.LinkTypeConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.MeteredConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.ObstacleConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.ProtectedConstraint
 
isValid(Link, ResourceContext) - Method in class org.onosproject.net.intent.constraint.TierConstraint
 
isValidCode() - Method in class org.onlab.packet.RADIUS
Checks if the packet's code field is valid.
isValidLength(String, int) - Method in class org.onosproject.net.config.Config
Indicates whether the specified field is of a valid length.
isValidType() - Method in class org.onlab.packet.RADIUSAttribute
Checks if the attribute type is valid.
isViable() - Method in class org.onlab.graph.ScalarWeight
 
isViable() - Method in interface org.onlab.graph.Weight
Returns true if the weighted subject (link/path) can be traversed; false otherwise.
isWarnEnabled() - Method in class org.onlab.junit.LoggerAdapter
 
isWarnEnabled(Marker) - Method in class org.onlab.junit.LoggerAdapter
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.onlab.rest.JsonBodyWriter
 
isZero() - Method in class org.onlab.packet.IpAddress
Check if this IP address is zero.
isZero() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
isZero() - Method in interface org.onosproject.net.device.PortStatistics
Returns true if all the port stats are zero, excluding TxErrors and RxErrors.
ItemNotFoundException - Exception in org.onlab.util
Represents condition where an item is not found or not available.
ItemNotFoundException() - Constructor for exception org.onlab.util.ItemNotFoundException
Creates a new exception with no message.
ItemNotFoundException(String) - Constructor for exception org.onlab.util.ItemNotFoundException
Creates a new exception with the supplied message.
ItemNotFoundException(String, Throwable) - Constructor for exception org.onlab.util.ItemNotFoundException
Creates a new exception with the supplied message and cause.
iterator() - Method in class org.onlab.graph.Heap
Returns iterator to traverse the heap level-by-level.
iterator() - Method in class org.onlab.util.ExtendedSet
 
iterator() - Method in class org.onlab.util.Generator
 
iterator() - Method in class org.onlab.util.UnmodifiableDeque
 
iterator() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
iterator() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
iterator() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
iterator() - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
iterator() - Method in interface org.onosproject.store.service.AsyncIterable
Returns an asynchronous iterator.

J

jitter() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link jitter in terms of seconds.
jitter(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link jitter.
JITTER - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for jitter.
JITTER - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
join() - Method in class org.onlab.util.BlockingAwareFuture
 
js() - Method in class org.onosproject.ui.UiExtension
Returns input stream containing JavaScript inclusion statements.
json(ObjectMapper, Iterable<DeviceId>) - Static method in class org.onosproject.cli.MastersListCommand
Produces a JSON array containing the specified device identifiers.
json(AbstractShellCommand, Iterable<? extends Path>) - Static method in class org.onosproject.cli.net.PathListCommand
Produces a JSON array containing the specified paths.
json(AbstractShellCommand, Iterable<Link>) - Static method in class org.onosproject.cli.net.LinksListCommand
Produces a JSON array containing the specified links.
json(AbstractShellCommand, Link) - Static method in class org.onosproject.cli.net.LinksListCommand
Produces a JSON object for the specified link.
json(Highlights) - Static method in class org.onosproject.ui.topo.TopoJson
Transforms the given highlights model into a JSON message payload.
json(PropertyPanel) - Static method in class org.onosproject.ui.topo.TopoJson
Translates the given property panel into JSON, for returning to the client.
JsonBodyWriter - Class in org.onlab.rest
JAX-RS Response message body writer.
JsonBodyWriter() - Constructor for class org.onlab.rest.JsonBodyWriter
 
JsonCodec<T> - Class in org.onosproject.codec
Abstraction of a codec capable for encoding/decoding arbitrary objects to/from JSON.
JsonCodec() - Constructor for class org.onosproject.codec.JsonCodec
 
jsonForEntity(T, Class<T>) - Method in class org.onosproject.cli.AbstractShellCommand
Generates a Json representation of an object.
jsonPorts(DeviceService, ObjectMapper, Device) - Method in class org.onosproject.cli.net.DevicePortsListCommand
Produces JSON array containing ports of the specified device.
jsonPorts(DeviceService, Iterable<Device>) - Method in class org.onosproject.cli.net.DevicePortsListCommand
Produces JSON array containing ports of the specified devices.
jsonPortStats(DeviceService, Iterable<Device>) - Method in class org.onosproject.cli.net.DevicePortStatsCommand
Produces JSON array containing portstats of the specified devices.
jsonPortStatsDelta(DeviceService, Iterable<Device>) - Method in class org.onosproject.cli.net.DevicePortStatsCommand
Produces JSON array containing delta portstats of the specified devices.
JsonUtils - Class in org.onosproject.ui
Provides convenience methods for dealing with JSON nodes, arrays etc.

K

KB_PER_SEC - org.onosproject.net.behaviour.trafficcontrol.Policer.Unit
KByte per second.
KB_PER_SEC - org.onosproject.net.meter.Meter.Unit
Kilo bits per second.
kbps(double) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in Kbps.
kbps(long) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in Kbps.
kBps(double) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in KBps.
kBps(long) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in KBps.
KBPS - org.onlab.util.DataRateUnit
Kilobit per second.
keepSubdued() - Method in class org.onosproject.ui.topo.AbstractHighlight
Sets a flag to tell the renderer to keep this element subdued.
key - Variable in class org.onosproject.net.config.Config
 
key - Variable in class org.onosproject.net.intent.Intent.Builder
 
key() - Method in class org.onosproject.cli.net.AddProtectedTransportIntentCommand
Returns Key if specified in the option.
key() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
Creates a key for an intent based on command line arguments.
key() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
key() - Method in interface org.onosproject.net.behaviour.TunnelDescription
Returns the tunnel key.
key() - Method in class org.onosproject.net.config.Config
Returns the configuration key.
key() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
key() - Method in interface org.onosproject.net.flowobjective.FilteringObjective
Obtain the key for this filter.
key() - Method in class org.onosproject.net.group.DefaultGroupKey
 
key() - Method in interface org.onosproject.net.group.GroupKey
Returns the byte representation of key.
key() - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
Returns the key of link annotation this constraint designates.
key() - Method in class org.onosproject.net.intent.Intent
Returns the key to identify an "Intent".
key() - Method in class org.onosproject.net.intent.IntentData
Returns the intent key.
key() - Method in class org.onosproject.net.intent.IntentOperation
Returns the key for this intent.
key() - Method in class org.onosproject.net.pi.runtime.PiGroupKey
 
key() - Method in class org.onosproject.rest.ApiDocProvider
Returns the REST API key.
key() - Method in class org.onosproject.store.primitives.MapUpdate
Returns the item key being updated.
key() - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
Returns the key this event concerns.
key() - Method in class org.onosproject.store.service.MapEvent
Returns the key this event concerns.
key() - Method in class org.onosproject.store.service.MultimapEvent
Returns the key this event concerns.
key() - Method in class org.onosproject.ui.chart.ChartModel.Annot
Returns the annotation's key.
key() - Method in class org.onosproject.ui.lion.LionBundle.LionItem
Returns the key.
key() - Method in class org.onosproject.ui.table.TableModel.Annot
Returns the annotation's key.
key() - Method in class org.onosproject.ui.topo.BiLink
Returns the key for this bi-link.
key() - Method in class org.onosproject.ui.topo.PropertyPanel.Prop
Returns the property's key.
key(TunnelKey) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
key(TunnelKey) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface description builder with a tunnel key.
key(DeviceId) - Static method in class org.onosproject.net.meter.MeterFeaturesKey
Deprecated.
 
key(DeviceId, MeterCellId) - Static method in class org.onosproject.net.meter.MeterKey
 
key(DeviceId, MeterId) - Static method in class org.onosproject.net.meter.MeterKey
Deprecated.
in onos-2.5 replaced by MeterKey.key(DeviceId,MeterCellId) extends MeterKey to support both MeterId and PiMeterCellId
key(DeviceId, MeterScope) - Static method in class org.onosproject.net.meter.MeterTableKey
 
key(Key) - Method in class org.onosproject.net.domain.DomainIntent.Builder
 
key(Key) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.ConnectivityIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.Intent.Builder
Sets the key for the intent that will be built.
key(Key) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.PathIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
 
key(Key) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
 
Key - Class in org.onosproject.net.intent
Key class for Intents.
Key(long) - Constructor for class org.onosproject.net.intent.Key
 
KEY_AN_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
keyId - Variable in class org.onlab.packet.RIPV2AuthEntry
 
keys() - Method in class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
 
keys() - Method in interface org.onosproject.net.Annotations
Returns the set of keys for available annotations.
keys() - Method in class org.onosproject.net.DefaultAnnotations
 
keys() - Method in class org.onosproject.net.driver.DefaultDriver
 
keys() - Method in class org.onosproject.net.driver.DefaultDriverData
 
keys() - Method in interface org.onosproject.net.SparseAnnotations
Returns the set of keys for available annotations.
keys() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
keys() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns a multiset of the keys present in this multimap with one or more associated values each.
keys() - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns a multiset of the keys present in this multimap with one or more associated values each.
KEYSERVER_MASK - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
KEYSERVER_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
keySet() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
keySet() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
keySet() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
keySet() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
keySet() - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns a Set view of the keys contained in this map.
keySet() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns a set of the keys contained in this multimap with one or more associated values.
keySet() - Method in interface org.onosproject.store.service.ConsistentMap
Returns a Set view of the keys contained in this map.
keySet() - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns a set of the keys contained in this multimap with one or more associated values.
keySet() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Returns a set of the keys in this map.
KILO - org.onosproject.ui.topo.TopoUtils.Magnitude
 
kilometersTo(GeoLocation) - Method in class org.onlab.util.GeoLocation
Returns the distance in kilometers, between this location and another.
KryoNamespace - Class in org.onlab.util
Pool of Kryo instances, with classes pre-registered.
KryoNamespace.Builder - Class in org.onlab.util
KryoNamespace builder.
KryoNamespaces - Class in org.onosproject.store.serializers
 
KShortestPathsSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Runs K shortest paths algorithm on a provided directed graph.
KShortestPathsSearch() - Constructor for class org.onlab.graph.KShortestPathsSearch
 
KShortestPathsSearch.InnerOrderedResult - Class in org.onlab.graph
A result modified to return paths ordered according to the provided comparator.

L

L_BAND_MAX - Static variable in class org.onlab.util.Spectrum
 
L_BAND_MIN - Static variable in class org.onlab.util.Spectrum
 
L0MODIFICATION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be modified in L0 way.
L0ModificationInstruction - Class in org.onosproject.net.flow.instructions
 
L0ModificationInstruction() - Constructor for class org.onosproject.net.flow.instructions.L0ModificationInstruction
 
L0ModificationInstruction.L0SubType - Enum in org.onosproject.net.flow.instructions
Represents the type of traffic treatment.
L0ModificationInstruction.ModOchSignalInstruction - Class in org.onosproject.net.flow.instructions
Represents an L0 OCh (Optical Channel) modification instruction.
L1_PORT_ID - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
The port on which the INT packet was received and sent out.
L1MODIFICATION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be modified in L1 way.
L1ModificationInstruction - Class in org.onosproject.net.flow.instructions
 
L1ModificationInstruction() - Constructor for class org.onosproject.net.flow.instructions.L1ModificationInstruction
 
L1ModificationInstruction.L1SubType - Enum in org.onosproject.net.flow.instructions
Represents the type of traffic treatment.
L1ModificationInstruction.ModOduSignalIdInstruction - Class in org.onosproject.net.flow.instructions
Represents an L1 ODU (Optical channel Data Unit) Signal Id modification instruction.
L2_PORT_ID - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
The logical ports on which the INT packet was received and sent out.
L2MODIFICATION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be modified in L2 way.
L2ModificationInstruction - Class in org.onosproject.net.flow.instructions
Abstraction of a single traffic treatment step.
L2ModificationInstruction() - Constructor for class org.onosproject.net.flow.instructions.L2ModificationInstruction
 
L2ModificationInstruction.L2SubType - Enum in org.onosproject.net.flow.instructions
Represents the type of traffic treatment.
L2ModificationInstruction.ModEtherInstruction - Class in org.onosproject.net.flow.instructions
Represents a L2 src/dst modification instruction.
L2ModificationInstruction.ModMplsBosInstruction - Class in org.onosproject.net.flow.instructions
Represents a MPLS BOS modification.
L2ModificationInstruction.ModMplsHeaderInstruction - Class in org.onosproject.net.flow.instructions
Represents a MPLS header modification instruction.
L2ModificationInstruction.ModMplsLabelInstruction - Class in org.onosproject.net.flow.instructions
Represents a MPLS label modification.
L2ModificationInstruction.ModMplsTtlInstruction - Class in org.onosproject.net.flow.instructions
Represents a MPLS TTL modification.
L2ModificationInstruction.ModTunnelIdInstruction - Class in org.onosproject.net.flow.instructions
Represents a Tunnel id modification.
L2ModificationInstruction.ModVlanHeaderInstruction - Class in org.onosproject.net.flow.instructions
Represents a VLAN Header modification instruction.
L2ModificationInstruction.ModVlanIdInstruction - Class in org.onosproject.net.flow.instructions
Represents a VLAN id modification instruction.
L2ModificationInstruction.ModVlanPcpInstruction - Class in org.onosproject.net.flow.instructions
Represents a VLAN PCP modification instruction.
L2SwitchVlanConfigBehaviour - Interface in org.onosproject.net.behaviour
Means to configure VLANs on legacy L2 switch devices.
L3MODIFICATION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be modified in L3 way.
L3ModificationInstruction - Class in org.onosproject.net.flow.instructions
Abstraction of a single traffic treatment step.
L3ModificationInstruction() - Constructor for class org.onosproject.net.flow.instructions.L3ModificationInstruction
 
L3ModificationInstruction.L3SubType - Enum in org.onosproject.net.flow.instructions
Represents the type of traffic treatment.
L3ModificationInstruction.ModArpEthInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 ARP Ether src/dst modification instruction.
L3ModificationInstruction.ModArpIPInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 ARP IP src/dst modification instruction.
L3ModificationInstruction.ModArpOpInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 ARP operation modification instruction.
L3ModificationInstruction.ModDscpInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 DSCP modification instruction.
L3ModificationInstruction.ModIPInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 src/dst modification instruction.
L3ModificationInstruction.ModIPv6FlowLabelInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 IPv6 Flow Label (RFC 6437) modification instruction (20 bits unsigned integer).
L3ModificationInstruction.ModTtlInstruction - Class in org.onosproject.net.flow.instructions
Represents a L3 TTL modification instruction.
L4MODIFICATION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be modified in L4 way.
L4ModificationInstruction - Class in org.onosproject.net.flow.instructions
Abstraction of a single traffic treatment step.
L4ModificationInstruction() - Constructor for class org.onosproject.net.flow.instructions.L4ModificationInstruction
 
L4ModificationInstruction.L4SubType - Enum in org.onosproject.net.flow.instructions
Represents the type of traffic treatment.
L4ModificationInstruction.ModTransportPortInstruction - Class in org.onosproject.net.flow.instructions
Represents a L4 src/dst modification instruction.
label - Variable in class org.onlab.packet.MPLS
 
label() - Method in class org.onosproject.net.flow.criteria.MplsCriterion
 
label() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsLabelInstruction
 
label() - Method in class org.onosproject.net.key.DeviceKey
Returns the label of device key.
label() - Method in class org.onosproject.ui.topo.LinkHighlight
Returns the label text.
label() - Method in class org.onosproject.ui.topo.PropertyPanel.Prop
Returns the property's (localized) label.
label() - Method in class org.onosproject.ui.UiView
Returns the view label.
LABEL - Static variable in class org.onosproject.ui.chart.ChartRequestHandler
 
Lacp - Class in org.onlab.packet.lacp
 
Lacp() - Constructor for class org.onlab.packet.lacp.Lacp
 
LACP - Static variable in class org.onlab.packet.MacAddress
LACP MAC address.
LacpBaseTlv - Class in org.onlab.packet.lacp
Represents LACP ActorInfo or PartnerInfo information.
LacpBaseTlv() - Constructor for class org.onlab.packet.lacp.LacpBaseTlv
 
LacpCollectorTlv - Class in org.onlab.packet.lacp
Represents LACP collector information.
LacpCollectorTlv() - Constructor for class org.onlab.packet.lacp.LacpCollectorTlv
 
LacpState - Class in org.onlab.packet.lacp
LACP state.
LacpState() - Constructor for class org.onlab.packet.lacp.LacpState
Constructs LACP state with zero value.
LacpState(byte) - Constructor for class org.onlab.packet.lacp.LacpState
Constructs LACP state with given value.
LacpTerminatorTlv - Class in org.onlab.packet.lacp
Represents LACP terminator information.
LacpTerminatorTlv() - Constructor for class org.onlab.packet.lacp.LacpTerminatorTlv
 
LacpTlv - Class in org.onlab.packet.lacp
 
LacpTlv() - Constructor for class org.onlab.packet.lacp.LacpTlv
 
lambda() - Method in class org.onosproject.net.flow.criteria.LambdaCriterion
Gets the lambda (wavelength) to match.
lambda() - Method in class org.onosproject.net.flow.criteria.OchSignalCriterion
Returns the OCh signal to match.
lambda() - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction.ModOchSignalInstruction
 
lambda() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
lambda(OchSignal) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
Sets the optical channel (lambda) for the intent that will be built.
Lambda - Interface in org.onosproject.net
Abstraction of wavelength.
LambdaCriterion - Class in org.onosproject.net.flow.criteria
Implementation of lambda (wavelength) criterion (16 bits unsigned integer).
LambdaQuery - Interface in org.onosproject.net.behaviour
A HandlerBehaviour to retrieve available wavelength resources.
lastEntry() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
lastEntry() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the entry associated with the highest key in the map.
lastEntry() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the highest key in the map.
lastEventTimestampGauge() - Method in class org.onlab.metrics.EventMetric
Gets the last event timestamp Gauge (ms from the Epoch).
lastKey() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
lastKey() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the highest key in the map.
lastKey() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the highest key in the map.
lastSeen() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
lastSeen() - Method in interface org.onosproject.net.flow.FlowEntry
When this flow entry was last deemed active.
lastUpdate(String) - Method in interface org.onosproject.cpman.MetricsDatabase
Returns the latest metric update time.
latency() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link latency in terms of nanos.
latency() - Method in class org.onosproject.net.intent.constraint.LatencyConstraint
 
latency(Duration) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link latency.
LATENCY - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for latency.
LATENCY - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
LatencyConstraint - Class in org.onosproject.net.intent.constraint
Constraint that evaluates the latency through a path.
LatencyConstraint(Duration) - Constructor for class org.onosproject.net.intent.constraint.LatencyConstraint
Creates a new constraint to keep under specified latency through a path.
latest() - Method in class org.onosproject.cpman.ControlLoadSnapshot
Returns latest value of control metric.
latest() - Method in class org.onosproject.net.statistic.DefaultLoad
 
latest() - Method in interface org.onosproject.net.statistic.Load
Obtain the latest bytes counter viewed on that link.
LATEST_KEY_AN_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
LATEST_KEY_RX_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
LATEST_KEY_TX_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
latitude() - Method in class org.onlab.util.GeoLocation
Returns the latitude of this location.
latitude() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns element latitude.
latitude(Double) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the element latitude.
LATITUDE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for latitude (e.g.
LATITUDE - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for latitude.
LATITUDE - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
latOrY() - Method in class org.onosproject.ui.topo.LayoutLocation
Returns the latitude (geo) or y-coord (grid) data value.
layer() - Method in class org.onosproject.ui.model.topo.UiNode
Returns the tag for the "layer" that the node should be rendered in when viewed in the oblique view.
LAYER - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the protocol layer.
LAYER_DEFAULT - Static variable in class org.onosproject.ui.model.topo.UiNode
Default "layer" tag.
LAYER_OPTICAL - Static variable in class org.onosproject.ui.model.topo.UiNode
Optical layer tag.
LAYER_PACKET - Static variable in class org.onosproject.ui.model.topo.UiNode
Packet layer tag.
layerOrder() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the order in which layers should be rendered.
layout() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a UI Topology Layout service implementation.
LAYOUT_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
LAYOUT_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
UI Topology layout ID subject factory.
LayoutAddCommand - Class in org.onosproject.cli.net
Add a new UI layout.
LayoutAddCommand() - Constructor for class org.onosproject.cli.net.LayoutAddCommand
 
layoutId(String) - Static method in class org.onosproject.ui.model.topo.UiTopoLayoutId
Returns the layout identifier created from the specified value.
LayoutListCommand - Class in org.onosproject.cli.net
List layout details.
LayoutListCommand() - Constructor for class org.onosproject.cli.net.LayoutListCommand
 
layoutLocation(String, String, double, double) - Static method in class org.onosproject.ui.topo.LayoutLocation
Creates an instance of a layout location.
layoutLocation(String, LayoutLocation.Type, double, double) - Static method in class org.onosproject.ui.topo.LayoutLocation
Creates an instance of a layout location.
LayoutLocation - Class in org.onosproject.ui.topo
Represents a "node location" on a UI layout.
LayoutLocation.Type - Enum in org.onosproject.ui.topo
Designates the type of location; either geographic or logical grid.
LazyKShortestPathsSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Lazily runs K shortest paths algorithm on a provided directed graph.
LazyKShortestPathsSearch() - Constructor for class org.onlab.graph.LazyKShortestPathsSearch
 
lazyPathSearch(Graph<V, E>, V, V, EdgeWeigher<V, E>) - Method in class org.onlab.graph.LazyKShortestPathsSearch
Searches the specified graph for paths between vertices.
leader() - Method in class org.onosproject.cluster.Leadership
Returns the leader for this topic.
leader() - Method in class org.onosproject.store.service.PartitionInfo
Returns the partition leader.
Leader - Class in org.onosproject.cluster
Topic leader.
Leader(NodeId, long, long) - Constructor for class org.onosproject.cluster.Leader
 
LEADER_AND_CANDIDATES_CHANGED - org.onosproject.cluster.LeadershipEvent.Type
Signifies a change in both the leader as well as change to the list of candidates.
LEADER_CHANGED - org.onosproject.cluster.LeadershipEvent.Type
Signifies that the leader for a topic has changed.
LEADER_CHANGED - org.onosproject.net.intent.WorkPartitionEvent.Type
 
LEADER_ELECTOR - org.onosproject.store.service.DistributedPrimitive.Type
Leader elector.
LeaderCommand - Class in org.onosproject.cli.net
Prints the leader for every topic.
LeaderCommand() - Constructor for class org.onosproject.cli.net.LeaderCommand
 
LeaderElector - Interface in org.onosproject.store.service
LeaderElector provides the same functionality as AsyncLeaderElector with the only difference that all its methods block until the corresponding operation completes.
leaderElectorBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new LeaderElectorBuilder.
leaderElectorBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new LeaderElectorBuilder.
LeaderElectorBuilder - Class in org.onosproject.store.service
Builder for constructing new AsyncLeaderElector instances.
LeaderElectorBuilder() - Constructor for class org.onosproject.store.service.LeaderElectorBuilder
 
LeaderElectorOptions<O extends LeaderElectorOptions<O>> - Class in org.onosproject.store.service
Builder for constructing new AsyncLeaderElector instances.
LeaderElectorOptions() - Constructor for class org.onosproject.store.service.LeaderElectorOptions
 
leaderNodeId() - Method in class org.onosproject.cluster.Leadership
Returns the nodeId of the leader.
Leadership - Class in org.onosproject.cluster
State of leadership for topic.
Leadership(String, Leader, List<NodeId>) - Constructor for class org.onosproject.cluster.Leadership
 
LeadershipAdminService - Interface in org.onosproject.cluster
Interface for administratively manipulating leadership assignments.
LeadershipEvent - Class in org.onosproject.cluster
Describes leadership-related event.
LeadershipEvent(LeadershipEvent.Type, Leadership) - Constructor for class org.onosproject.cluster.LeadershipEvent
Creates an event of a given type and for the specified instance and the current time.
LeadershipEvent(LeadershipEvent.Type, Leadership, long) - Constructor for class org.onosproject.cluster.LeadershipEvent
Creates an event of a given type and for the specified subject and time.
LeadershipEvent.Type - Enum in org.onosproject.cluster
Type of leadership events.
LeadershipEventListener - Interface in org.onosproject.cluster
Entity capable of receiving device leadership-related events.
LeadershipService - Interface in org.onosproject.cluster
Service for leader election.
LeadershipStore - Interface in org.onosproject.cluster
Store interface for managing LeadershipService state.
LeadershipStoreDelegate - Interface in org.onosproject.cluster
LeadershipStore delegate abstraction.
learn(PiHandle, PiTranslatedEntity<T, E>) - Method in interface org.onosproject.net.pi.service.PiTranslator
Stores a mapping between the given translated entity and handle.
LEARNED - org.onosproject.net.pi.service.PiTranslationEvent.Type
Signals that A PD entity has been translated to a PI one, and the mapping between the two entities has been learned by the system.
LEASE_QUERY - org.onlab.packet.DHCP6.OptionCode
 
leasePeriod() - Method in class org.onosproject.dhcp.IpAssignment
Returns the lease period of the IP assignment.
leasePeriod(int) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
leasePeriodMs() - Method in class org.onosproject.dhcp.IpAssignment
Returns the lease period of the IP assignment.
LEASEQUERY - org.onlab.packet.DHCP6.MsgType
 
LEASEQUERY_MSG_TYPES - Static variable in class org.onlab.packet.DHCP6
 
LEASEQUERY_REPLY - org.onlab.packet.DHCP6.MsgType
 
leastCommonAncestor(Collection<DocumentPath>) - Static method in class org.onosproject.store.service.DocumentPath
Returns the path that points to the least common ancestor of the specified collection of paths.
length - Variable in class org.onlab.packet.bmp.Bmp
 
length - Variable in class org.onlab.packet.dhcp.DhcpOption
 
length - Variable in class org.onlab.packet.EAP
 
length - Variable in class org.onlab.packet.LLDPTLV
 
length - Variable in class org.onlab.packet.PPPoEDTag
 
length - Variable in class org.onlab.packet.RADIUS
 
length - Variable in class org.onlab.packet.RADIUSAttribute
 
length - Variable in class org.onlab.packet.UDP
 
length() - Method in class org.onlab.packet.MacAddress
Returns the length of the MACAddress.
length() - Method in class org.onlab.util.XmlString
 
LENGTH - Static variable in class org.onlab.packet.lacp.LacpBaseTlv
 
LENGTH - Static variable in class org.onlab.packet.lacp.LacpCollectorTlv
 
LENGTH - Static variable in class org.onlab.packet.lacp.LacpTerminatorTlv
 
LENGTH_UNIT - Static variable in class org.onlab.packet.ipv6.Authentication
 
LENGTH_UNIT - Static variable in class org.onlab.packet.ipv6.BaseOptions
 
LENGTH_UNIT - Static variable in class org.onlab.packet.ipv6.Routing
 
life() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
life() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
The lifetime in seconds of this policer.
life() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
life() - Method in interface org.onosproject.net.flow.FlowEntry
Returns the number of seconds this flow rule has been applied.
life() - Method in class org.onosproject.net.group.DefaultGroup
Returns the number of milliseconds this group has been alive.
life() - Method in interface org.onosproject.net.group.Group
Returns the number of milliseconds this group has been alive.
life() - Method in class org.onosproject.net.meter.DefaultMeter
 
life() - Method in interface org.onosproject.net.meter.Meter
The lifetime in seconds of this meter.
life(TimeUnit) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
life(TimeUnit) - Method in interface org.onosproject.net.flow.FlowEntry
Returns the time this flow rule has been applied.
lineActive() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
Defines if the line related to the attachment is active.
link() - Method in class org.onosproject.net.topology.DefaultTopologyEdge
 
link() - Method in interface org.onosproject.net.topology.TopologyEdge
Returns the associated infrastructure link.
link() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a link service implementation.
link() - Method in class org.onosproject.ui.model.topo.UiSynthLink
Returns the link.
Link - Interface in org.onosproject.net
Abstraction of a network infrastructure link.
LINK - org.onosproject.ui.topo.TopoElementType
 
LINK_ADDED - org.onosproject.net.link.LinkEvent.Type
Signifies that a new link has been detected.
LINK_ADDED_OR_UPDATED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
LINK_EVENT - org.onosproject.security.AppPermission.Type
 
LINK_LOCAL_0 - Static variable in class org.onlab.packet.IPv6
 
LINK_LOCAL_1 - Static variable in class org.onlab.packet.IPv6
 
LINK_READ - org.onosproject.security.AppPermission.Type
 
LINK_REMOVED - org.onosproject.net.link.LinkEvent.Type
Signifies that a link has been removed.
LINK_REMOVED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
LINK_SELECTION - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
LINK_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
Link key subject factory.
LINK_UPDATED - org.onosproject.net.link.LinkEvent.Type
Signifies that a link has been updated or changed state.
LINK_WEIGHT_FUNCTION - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
LINK_WEIGHT_FUNCTION_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
LINK_WRITE - org.onosproject.security.AppPermission.Type
 
Link.State - Enum in org.onosproject.net
Representation of the link state, which applies primarily only to configured durable links, i.e.
Link.Type - Enum in org.onosproject.net
Coarse representation of the link type.
linkAddress - Variable in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
LinkAdminService - Interface in org.onosproject.net.link
Service for administering the inventory of infrastructure links.
linkAtoB() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Returns backing link from A to B.
linkBtoA() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Returns backing link from B to A.
LinkCollectionIntent - Class in org.onosproject.net.intent
Abstraction of a connectivity intent that is implemented by a set of path segments.
LinkCollectionIntent() - Constructor for class org.onosproject.net.intent.LinkCollectionIntent
Constructor for serializer.
LinkCollectionIntent.Builder - Class in org.onosproject.net.intent
Builder of a single point to multi point intent.
linkCount() - Method in class org.onosproject.common.DefaultTopology
 
linkCount() - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
linkCount() - Method in interface org.onosproject.net.topology.Topology
Returns the number of infrastructure links in the topology.
linkCount() - Method in interface org.onosproject.net.topology.TopologyCluster
Returns the number of infrastructure links in the cluster.
LinkDescription - Interface in org.onosproject.net.link
Describes an infrastructure link.
linkDetected(LinkDescription) - Method in interface org.onosproject.net.link.LinkProviderService
Signals that an infrastructure link has been detected.
LinkDiscovery - Interface in org.onosproject.net.behaviour
A HandlerBehaviour to discover links.
LinkDstCompleter - Class in org.onosproject.cli.net
Link destination end-point completer.
LinkDstCompleter() - Constructor for class org.onosproject.cli.net.LinkDstCompleter
 
LinkEvent - Class in org.onosproject.net.link
Describes infrastructure link event.
LinkEvent(LinkEvent.Type, Link) - Constructor for class org.onosproject.net.link.LinkEvent
Creates an event of a given type and for the specified link and the current time.
LinkEvent(LinkEvent.Type, Link, long) - Constructor for class org.onosproject.net.link.LinkEvent
Creates an event of a given type and for the specified link and time.
LinkEvent.Type - Enum in org.onosproject.net.link
Type of link events.
LinkHighlight - Class in org.onosproject.ui.topo
Denotes the highlighting to be applied to a link.
LinkHighlight(String, LinkHighlight.Flavor) - Constructor for class org.onosproject.ui.topo.LinkHighlight
Constructs a link highlight entity.
LinkHighlight.Flavor - Enum in org.onosproject.ui.topo
Link highlighting flavor.
linkId() - Method in class org.onosproject.ui.topo.BiLink
Returns the link identifier in the form expected on the Topology View in the web client.
linkKey(ConnectPoint, ConnectPoint) - Static method in class org.onosproject.net.LinkKey
Creates a link identifier with source and destination connection point.
linkKey(Link) - Static method in class org.onosproject.net.LinkKey
Creates a link identifier for the specified link.
linkKey(LinkDescription) - Static method in class org.onosproject.net.LinkKey
Creates a link identifier for the specified link.
LinkKey - Class in org.onosproject.net
Immutable representation of a link identity.
LinkKeySerializer - Class in org.onosproject.store.serializers
Kryo Serializer for LinkKey.
LinkKeySerializer() - Constructor for class org.onosproject.store.serializers.LinkKeySerializer
Creates LinkKey serializer instance.
LinkListener - Interface in org.onosproject.net.link
Entity capable of receiving infrastructure link related events.
LinkProvider - Interface in org.onosproject.net.link
Abstraction of an entity providing information about infrastructure links to the core.
LinkProviderRegistry - Interface in org.onosproject.net.link
Abstraction of an infrastructure link provider registry.
LinkProviderService - Interface in org.onosproject.net.link
Means for injecting link information into the core.
links() - Method in class org.onosproject.net.DefaultDisjointPath
 
links() - Method in class org.onosproject.net.DefaultPath
 
links() - Method in class org.onosproject.net.domain.DomainPointToPointIntent
 
links() - Method in class org.onosproject.net.intent.LinkCollectionIntent
Returns the set of links that represent the network connections needed by this intent.
links() - Method in interface org.onosproject.net.Path
Returns sequence of links comprising the path.
links() - Method in class org.onosproject.ui.topo.Highlights
Returns the collection of link highlights.
links() - Method in class org.onosproject.ui.topo.NodeSelection
Returns a view of the selected links (hover not included).
links(List<Link>) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
Sets the links of the point to domain point intent that will be built.
links(Set<Link>) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
Sets the links of the link collection intent that will be built.
LINKS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
LinkService - Interface in org.onosproject.net.link
Service for interacting with the inventory of infrastructure links.
LinksListCommand - Class in org.onosproject.cli.net
Lists all infrastructure links.
LinksListCommand() - Constructor for class org.onosproject.cli.net.LinksListCommand
 
LinkSrcCompleter - Class in org.onosproject.cli.net
Link source end-point completer.
LinkSrcCompleter() - Constructor for class org.onosproject.cli.net.LinkSrcCompleter
 
LinkStore - Interface in org.onosproject.net.link
Manages inventory of infrastructure links; not intended for direct use.
LinkStoreDelegate - Interface in org.onosproject.net.link
Infrastructure link store delegate abstraction.
linkString(Link) - Static method in class org.onosproject.cli.net.LinksListCommand
Returns a formatted string representing the given link.
linksVanished(ConnectPoint) - Method in interface org.onosproject.net.link.LinkProviderService
Signals that infrastructure links associated with the specified connect point have vanished.
linksVanished(DeviceId) - Method in interface org.onosproject.net.link.LinkProviderService
Signals that infrastructure links associated with the specified device have vanished.
linksWithHover() - Method in class org.onosproject.ui.topo.NodeSelection
Returns a view of the selected links, including the hovered link if thee was one.
LinkTypeCompleter - Class in org.onosproject.cli.net.completer
Completer for Link.Type.
LinkTypeCompleter() - Constructor for class org.onosproject.cli.net.completer.LinkTypeCompleter
 
LinkTypeConstraint - Class in org.onosproject.net.intent.constraint
Constraint that evaluates links based on their type.
LinkTypeConstraint(boolean, Link.Type...) - Constructor for class org.onosproject.net.intent.constraint.LinkTypeConstraint
Creates a new constraint for requesting connectivity using or avoiding the specified link types.
linkVanished(LinkDescription) - Method in interface org.onosproject.net.link.LinkProviderService
Signals that an infrastructure link has disappeared.
LinkWeigher - Interface in org.onosproject.net.topology
Entity capable of determining cost or weight of a specified topology graph edge.
LionBundle - Class in org.onosproject.ui.lion
Encapsulates a bundle of localization strings.
LionBundle.Builder - Class in org.onosproject.ui.lion
Builder of Lion Bundles.
LionBundle.LionItem - Class in org.onosproject.ui.lion
Represents a single localization item.
lionBundles() - Method in class org.onosproject.ui.UiExtension
Returns the list of localization bundles that this extension is contributing.
lionBundles(List<LionBundle>) - Method in class org.onosproject.ui.UiExtension.Builder
Sets the localization bundles (aka LionBundles) that this UI extension is contributing.
LionUtils - Class in org.onosproject.ui.lion
Utility methods for dealing with Localization Bundles etc.
listAllMapping() - Method in interface org.onosproject.dhcp.DhcpStore
Returns a collection of all the MacAddress to IPAddress mapping.
listAssignedMapping() - Method in interface org.onosproject.dhcp.DhcpStore
Returns a collection of all the MacAddress to IPAddress mapping assigned to the hosts.
listenerRegistry - Variable in class org.onosproject.event.AbstractListenerManager
 
listenerRegistry - Variable in class org.onosproject.net.provider.AbstractListenerProviderRegistry
 
ListenerRegistry<E extends Event,​L extends EventListener<E>> - Class in org.onosproject.event
Base implementation of an event sink and a registry capable of tracking listeners and dispatching events to them as part of event sink processing.
ListenerRegistry() - Constructor for class org.onosproject.event.ListenerRegistry
 
listeners - Variable in class org.onosproject.event.ListenerRegistry
Set of listeners that have registered.
ListenerService<E extends Event,​L extends EventListener<E>> - Interface in org.onosproject.event
Abstraction of a service capable of asynchronously notifying listeners.
ListenerTracker - Class in org.onosproject.event
Utility to keeps track of registered Listeners.
ListenerTracker() - Constructor for class org.onosproject.event.ListenerTracker
 
listMapping() - Method in interface org.onosproject.dhcp.DhcpService
Returns a collection of all the MacAddress to IPAddress mapping.
liveType() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
liveType() - Method in interface org.onosproject.net.flow.FlowEntry
Gets the flow live type for this entry.
LLC - Class in org.onlab.packet
This class represents an Link Local Control header that is used in Ethernet 802.3.
LLC() - Constructor for class org.onlab.packet.LLC
 
LLC_HEADER_LENGTH - Static variable in class org.onlab.packet.LLC
 
LLDP - Class in org.onlab.packet
Representation of an LLDP Packet.
LLDP - org.onlab.packet.EthType.EtherType
 
LLDP - org.onosproject.cli.net.EthType
LLDP.
LLDP - Static variable in class org.onlab.packet.MacAddress
A set of LLDP MAC addresses.
LLDP() - Constructor for class org.onlab.packet.LLDP
 
LLDPOrganizationalTLV - Class in org.onlab.packet
The class representing LLDP Organizationally Specific TLV.
LLDPOrganizationalTLV() - Constructor for class org.onlab.packet.LLDPOrganizationalTLV
 
LLDPTLV - Class in org.onlab.packet
 
LLDPTLV() - Constructor for class org.onlab.packet.LLDPTLV
 
load() - Method in interface org.onosproject.cpman.ControlMessage
Returns the latest control message load.
load() - Method in class org.onosproject.cpman.DefaultControlMessage
 
load() - Method in class org.onosproject.net.statistic.FlowEntryWithLoad
Returns current load.
load() - Method in class org.onosproject.net.statistic.TypedFlowEntryWithLoad
 
load(long) - Method in class org.onosproject.cpman.MetricValue.Builder
Sets load value.
load(ConnectPoint) - Method in interface org.onosproject.net.statistic.PortStatisticsService
Obtain the egress load for the given port in terms of bytes per second.
load(ConnectPoint) - Method in interface org.onosproject.net.statistic.StatisticService
Obtain the load for the given port.
load(ConnectPoint, PortStatisticsService.MetricType) - Method in interface org.onosproject.net.statistic.PortStatisticsService
Obtain the egress load for the given port in terms of the specified metric.
load(Link) - Method in interface org.onosproject.net.statistic.StatisticService
Obtain the load for a the ingress to the given link.
load(Link, ApplicationId, Optional<GroupId>) - Method in interface org.onosproject.net.statistic.StatisticService
Obtain the load for a the ingress to the given link used by the specified application ID and group ID.
Load - Interface in org.onosproject.net.statistic
Simple data repository for link load information.
loadAllByType(Device, FlowEntry.FlowLiveType, Instruction.Type) - Method in interface org.onosproject.net.statistic.FlowStatisticService
Obtain the set of the flow type and load list for the device with the given link.
loadAllByType(Device, PortNumber, FlowEntry.FlowLiveType, Instruction.Type) - Method in interface org.onosproject.net.statistic.FlowStatisticService
Obtain the flow type and load list for the device with the given link or port.
loadDriver(HierarchicalConfiguration, DriverResolver) - Method in class org.onosproject.net.driver.XmlDriverLoader
Loads a driver from the supplied hierarchical configuration.
loadDrivers(InputStream, DriverResolver) - Method in class org.onosproject.net.driver.XmlDriverLoader
Loads the specified drivers resource as an XML stream and parses it to produce a ready-to-register driver provider.
loadDrivers(HierarchicalConfiguration, DriverResolver) - Method in class org.onosproject.net.driver.XmlDriverLoader
Loads a driver provider from the supplied hierarchical configuration.
loadSummary(Device) - Method in interface org.onosproject.net.statistic.FlowStatisticService
Obtain the summary load list for the device with the given link.
loadSummary(Device, PortNumber) - Method in interface org.onosproject.net.statistic.FlowStatisticService
Obtain the summary load for the device with the given link or port.
loadTopnByType(Device, FlowEntry.FlowLiveType, Instruction.Type, int) - Method in interface org.onosproject.net.statistic.FlowStatisticService
Obtain the set of the flow type and load topn list for the device with the given link.
loadTopnByType(Device, PortNumber, FlowEntry.FlowLiveType, Instruction.Type, int) - Method in interface org.onosproject.net.statistic.FlowStatisticService
Obtain the flow type and load topn list for the device with the given link or port.
LOC_TYPE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for UI location type of device/host (either 'geo' or 'grid').
LOC_TYPE - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for location type (geo or grid).
LOC_TYPE_GEO - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
 
LOC_TYPE_GRID - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
 
LOC_TYPE_NONE - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
 
local() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
local() - Method in interface org.onosproject.net.behaviour.TunnelDescription
Returns the local connection point.
local(TunnelEndPoint) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
local(TunnelEndPoint) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface description builder with a given local tunnel endpoint.
LOCAL - org.onosproject.net.PortNumber.Logical
 
LOCAL - Static variable in class org.onosproject.net.domain.DomainId
Represents the domain directly managed by ONOS.
LOCAL - Static variable in class org.onosproject.net.PortNumber
 
localeFromString(String) - Static method in class org.onosproject.ui.lion.LionUtils
Parses the given string into language and country codes, and returns a Locale instance initialized with those parameters.
localStatus(NodeId) - Method in interface org.onosproject.cluster.ClusterService
Returns a human readable form of the system time when the availability state was last updated.
localStatus(DeviceId) - Method in interface org.onosproject.net.device.DeviceService
Indicates how long ago the device connected or disconnected from this controller instance.
localStatus(DeviceId) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
localStatus(DeviceId) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
locateDriver() - Method in class org.onosproject.net.AbstractProjectableModel
Locates the driver to be used by this entity.
locateDriver() - Method in class org.onosproject.net.DefaultDevice
 
location() - Method in class org.onosproject.net.DefaultHost
 
location() - Method in class org.onosproject.net.host.DefaultHostDescription
 
location() - Method in interface org.onosproject.net.host.HostDescription
Returns the most recent location of the host on the network edge.
location() - Method in interface org.onosproject.net.Host
Returns the most recent host location where the host attaches to the network edge.
locationDevice() - Method in class org.onosproject.ui.model.topo.UiHost
Returns the identifier of the device to which the host is connected.
locationPort() - Method in class org.onosproject.ui.model.topo.UiHost
Returns the port number of the device to which the host is connected.
locations() - Method in class org.onosproject.net.config.basics.BasicHostConfig
Returns the location of the host.
locations() - Method in class org.onosproject.net.DefaultHost
 
locations() - Method in class org.onosproject.net.host.DefaultHostDescription
 
locations() - Method in interface org.onosproject.net.host.HostDescription
Returns all locations of the host on the network edge.
locations() - Method in interface org.onosproject.net.Host
Returns host locations where the host attaches to the network edge.
lock() - Method in class org.onosproject.store.primitives.DefaultDistributedLock
 
lock() - Method in interface org.onosproject.store.service.AsyncDistributedLock
Acquires the lock, blocking until it's available.
lock() - Method in interface org.onosproject.store.service.DistributedLock
Acquires the lock, blocking until it's available.
LOCK - org.onosproject.store.primitives.MapUpdate.Type
Acquires a read lock on a key.
LOCK - org.onosproject.store.service.DistributedPrimitive.Type
Distributed lock.
LOCK - Static variable in class org.onosproject.ui.GlyphConstants
 
lockBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new DistributedLockBuilder.
locType() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns the location type (geo or grid) for the element in the Topology View.
locType() - Method in class org.onosproject.ui.topo.LayoutLocation
Returns the location type (geo or grid), which indicates how the data is to be interpreted.
locType(String) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the location type (geo or grid) for the element in the Topology View.
log - Static variable in class org.onosproject.alarm.XmlEventParser
 
log - Static variable in class org.onosproject.cli.AbstractShellCommand
 
log - Variable in class org.onosproject.common.net.AbstractDeviceProvider
 
log - Variable in class org.onosproject.ui.UiTopo2Overlay
 
log - Variable in class org.onosproject.ui.UiTopoOverlay
Logger for this overlay.
log() - Method in class org.onosproject.net.PipelineTraceableOutput
Returns the log message as string.
log(Logger, Tools.LogLevel, String, Object...) - Static method in class org.onlab.util.Tools
Wrapper function that enables logger invocation with log level as a parameter.
LoggerAdapter - Class in org.onlab.junit
 
LoggerAdapter() - Constructor for class org.onlab.junit.LoggerAdapter
 
LOGICAL_GROUP - org.onosproject.net.region.Region.Type
Region represents a logical grouping.
LogicalClockService - Interface in org.onosproject.store.service
Service that issues logical timestamps.
logicalCounter() - Method in class org.onosproject.core.HybridLogicalTime
Returns the logical counter component of a HLT.
logicalTime() - Method in class org.onosproject.core.HybridLogicalTime
Returns the logical time component of a HLT.
LogicalTimestamp - Class in org.onosproject.store
Timestamp based on logical sequence value.
LogicalTimestamp(long) - Constructor for class org.onosproject.store.LogicalTimestamp
 
logUserAction(String, String) - Method in interface org.onosproject.security.AuditService
Logs the specified user action.
LONG - org.onosproject.cfg.ConfigProperty.Type
Indicates the value is a long.
LONG - org.onosproject.net.flow.FlowEntry.FlowLiveType
Indicates that this rule has been submitted for a long time.
LONG_FLOW - org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Indicates that this rule has been submitted for a long time.
longitude() - Method in class org.onlab.util.GeoLocation
Returns the longitude of this location.
longitude() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns element longitude.
longitude(Double) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the element longitude.
LONGITUDE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for longitude (e.g.
LONGITUDE - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for longitude.
LONGITUDE - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
longLoad() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Returns long load of connect point.
longOrX() - Method in class org.onosproject.ui.topo.LayoutLocation
Returns the longitude (geo) or x-coord (grid) data value.
lookForDeviceId() - Method in class org.onosproject.cli.net.PortNumberCompleter
Look for valid DeviceId in arguments passed so far.
lookup(short) - Static method in enum org.onlab.packet.EthType.EtherType
 
lookup(short) - Method in class org.onlab.packet.EthType
Looks up the ethertype by it's numerical representation and returns it's textual format.
lookup(PiHandle) - Method in interface org.onosproject.net.pi.service.PiTranslator
Returns a PI translated entity that was previously associated with the given handle, if present.
LOOP - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
loss() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link loss in terms of Percentage.
loss(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link loss.
LOSS - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for loss.
LOSS - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
lowerBound() - Method in class org.onlab.util.ClosedOpenRange
Returns the lower bound.
lowerEntry(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
lowerEntry(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Returns the entry associated with the largest key less than key.
lowerEntry(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the largest key less than key.
lowerKey(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
lowerKey(String) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return the entry associated with the greatest key less than key.
lowerKey(String) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns the entry associated with the greatest key less than key.
LOWEST - org.onosproject.net.packet.PacketPriority
 
lowValue() - Method in class org.onosproject.net.pi.runtime.PiRangeFieldMatch
Returns the low value of this range field match.
LPM - org.onosproject.net.pi.model.PiMatchType
Longest-prefix match type.

M

mac() - Method in class org.onosproject.net.DefaultHost
 
mac() - Method in class org.onosproject.net.flow.criteria.ArpHaCriterion
Gets the MAC Address to match.
mac() - Method in class org.onosproject.net.flow.criteria.EthCriterion
Gets the MAC address to match.
mac() - Method in class org.onosproject.net.flow.criteria.IPv6NDLinkLayerAddressCriterion
Gets the MAC link-layer address to match.
mac() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModEtherInstruction
 
mac() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpEthInstruction
 
mac() - Method in interface org.onosproject.net.Host
Returns the host MAC address.
mac() - Method in class org.onosproject.net.HostId
Returns the host MAC address.
mac() - Method in class org.onosproject.net.intf.Interface
Retrieves the MAC address that is assigned to the interface.
mac() - Method in class org.onosproject.routing.NextHop
Returns the next hop's MAC address.
MAC - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
MAC - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
MAC_ADDRESS_LENGTH - Static variable in class org.onlab.packet.MacAddress
 
macAddress() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
Returns the MAC address of the attachment.
MacAddress - Class in org.onlab.packet
The class representing MAC address.
MacAddress(byte[]) - Constructor for class org.onlab.packet.MacAddress
 
MacAddressSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for MacAddress.
MacAddressSerializer() - Constructor for class org.onosproject.store.serializers.MacAddressSerializer
Creates MacAddress serializer instance.
MACSEC_CAPABILITY_MASK - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
MACSEC_CAPABILITY_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
MACSEC_DESIRED_MASK - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
MACSEC_DESIRED_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
magnitude() - Method in class org.onosproject.ui.topo.TopoUtils.ValueLabel
Returns the magnitude value.
major() - Method in class org.onosproject.core.Version
Returns the major version number.
MAJOR - org.onosproject.alarm.Alarm.SeverityLevel
X.733 definition: This indicates that a service affecting condition has developed and an urgent corrective action is required.
makeMaskedAddress(Ip4Address, int) - Static method in class org.onlab.packet.Ip4Address
Creates an IPv4 address by masking it with a network mask of given mask length.
makeMaskedAddress(Ip6Address, int) - Static method in class org.onlab.packet.Ip6Address
Creates an IPv6 address by masking it with a network mask of given mask length.
makeMaskedAddress(IpAddress, int) - Static method in class org.onlab.packet.IpAddress
Creates an IP address by masking it with a network mask of given mask length.
makeMaskPrefix(int) - Static method in class org.onlab.packet.Ip4Address
Creates an IPv4 network mask prefix.
makeMaskPrefix(int) - Static method in class org.onlab.packet.Ip6Address
Creates an IPv6 network mask prefix.
makeMaskPrefix(IpAddress.Version, int) - Static method in class org.onlab.packet.IpAddress
Creates an IP network mask prefix.
makePermanent() - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
makePermanent() - Method in interface org.onosproject.net.flow.FlowRule.Builder
Makes this rule permanent on the dataplane.
makePermanent() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
makePermanent() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
makePermanent() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
Noop.
makePermanent() - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Makes the filtering objective permanent.
makePermanent() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Makes the filtering objective permanent.
makePermanent() - Method in interface org.onosproject.net.flowobjective.Objective.Builder
Makes the filtering objective permanent.
makeTemporary(int) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
makeTemporary(int) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Makes this rule temporary and timeout after the specified amount of time.
makeTemporary(int) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
makeTemporary(int) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
makeTemporary(int) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
Noop.
makeTemporary(int) - Method in interface org.onosproject.net.flowobjective.Objective.Builder
Makes the filtering objective temporary.
makeTopCandidate(String, NodeId) - Method in interface org.onosproject.cluster.LeadershipStore
Attempts to make a node the top candidate.
MANAGEMENT_ADDRESS - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the management address.
managementAddress() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device management address (e.g, "ip:port" or full URI string).
managementAddress(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device management ip (ip:port).
MANDATORY - org.onosproject.net.config.Config.FieldPresence
Signifies that config field is mandatory.
manuallyClearable() - Method in interface org.onosproject.alarm.Alarm
Returns a flag to indicate if this alarm is manually-cleared by a user action within ONOS.
manuallyClearable() - Method in class org.onosproject.alarm.DefaultAlarm
 
manufacturer() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device manufacturer.
manufacturer() - Method in class org.onosproject.net.DefaultDevice
 
manufacturer() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
manufacturer() - Method in interface org.onosproject.net.device.DeviceDescription
Returns the device manufacturer name.
manufacturer() - Method in interface org.onosproject.net.Device
Returns the device manufacturer name.
manufacturer() - Method in class org.onosproject.net.driver.DefaultDriver
 
manufacturer() - Method in interface org.onosproject.net.driver.Driver
Returns the device manufacturer name.
manufacturer() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
manufacturer(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device manufacturer.
map(Function<E, F>) - Method in class org.onosproject.store.service.Task
Maps task from one payload type to another.
map(Function<K, S>, Function<V, T>) - Method in class org.onosproject.store.primitives.MapUpdate
Transforms this instance into an instance of different parameterized types.
map(Function<T, U>) - Method in class org.onosproject.store.service.TransactionLog
Maps this instance to another MapTransaction with different key and value types.
map(Function<T, V>) - Method in class org.onlab.util.Match
Maps this instance to a Match of another type.
map(Function<V, T>) - Method in class org.onosproject.store.primitives.NodeUpdate
Transforms this instance into an instance of different parameterized types.
map(Function<V, U>) - Method in class org.onosproject.store.service.Versioned
Maps this instance into another after transforming its value while retaining the same version and creationTime.
MAP - Static variable in class org.onosproject.ui.GlyphConstants
 
mapCriterionType(Criterion.Type) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
Returns a PI match field ID that is equivalent to the given criterion type, if present.
MapEvent<K,​V> - Class in org.onosproject.store.service
Representation of a ConsistentMap update notification.
MapEvent(String, K, Versioned<V>, Versioned<V>) - Constructor for class org.onosproject.store.service.MapEvent
Creates a new event object.
MapEvent(MapEvent.Type, String, K, Versioned<V>, Versioned<V>) - Constructor for class org.onosproject.store.service.MapEvent
Creates a new event object.
MapEvent.Type - Enum in org.onosproject.store.service
MapEvent type.
MapEventListener<K,​V> - Interface in org.onosproject.store.service
Listener to be notified about updates to a ConsistentMap.
mapFlowRuleTableId(int) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
Returns a PI table ID equivalent to the given numeric table ID (as in FlowRule.tableId()).
mapInboundPacket(PiPacketOperation, DeviceId) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
Returns an inbound packet equivalent to the given PI packet-in operation for the given device.
MapInfo - Class in org.onosproject.store.service
Metadata information for a consistent map.
MapInfo(String, int) - Constructor for class org.onosproject.store.service.MapInfo
 
mapLogicalPortNumber(PortNumber) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
Maps the given logical port number to the data plane port ID (integer) identifying the same port for this pipeconf, if such mapping is possible.
mapOutboundPacket(OutboundPacket) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
Returns a collection of PI packet operations equivalent to the given outbound packet instance.
mapper - Variable in class org.onosproject.net.config.Config
 
mapper() - Method in class org.onosproject.cli.AbstractShellCommand
 
mapper() - Method in interface org.onosproject.codec.CodecContext
Returns the JSON object mapper.
mapper() - Method in class org.onosproject.net.config.BaseConfig
 
mapper() - Method in class org.onosproject.rest.AbstractWebResource
 
MAPPER - Static variable in class org.onosproject.ui.RequestHandler
 
mappingCltSignalTypeToOduSignalType(CltSignalType) - Static method in class org.onosproject.net.OduSignalUtils
Maps from OduClt SignalType to OduSignalType.
mappingOtuSignalTypeToOduSignalType(OtuSignalType) - Static method in class org.onosproject.net.OduSignalUtils
Maps from OtuPort SignalType to OduSignalType.
MapsListCommand - Class in org.onosproject.cli.net
Command to list the various maps in the system.
MapsListCommand() - Constructor for class org.onosproject.cli.net.MapsListCommand
 
mapTreatment(TrafficTreatment, PiTableId) - Method in interface org.onosproject.net.pi.model.PiPipelineInterpreter
Returns an action of a PI pipeline that is functionally equivalent to the given traffic treatment for the given table.
MapUpdate<K,​V> - Class in org.onosproject.store.primitives
Map update operation.
MapUpdate() - Constructor for class org.onosproject.store.primitives.MapUpdate
 
MapUpdate.Builder<K,​V> - Class in org.onosproject.store.primitives
MapUpdate builder.
MapUpdate.Type - Enum in org.onosproject.store.primitives
Type of database update operation.
MARK_RED - org.onosproject.net.meter.Band.Type
Defines a meter band for the configuration of the peak rate AND the peak burst size OR the excess burst size.
MARK_YELLOW - org.onosproject.net.meter.Band.Type
Defines a meter band for the configuration of the committed rate AND the committed burst size.
MarkCommand - Class in org.onosproject.cli
CLI command which just log message to ONOS log for ease of debugging, etc.
MarkCommand() - Constructor for class org.onosproject.cli.MarkCommand
 
marker(String) - Static method in class org.onosproject.net.MarkerResource
Creates an instance of MarkerResource.
MarkerConstraint - Class in org.onosproject.net.intent.constraint
Abstract Constraint for constraints not intended to influence individual link cost or path validity.
MarkerConstraint() - Constructor for class org.onosproject.net.intent.constraint.MarkerConstraint
 
MarkerResource - Class in org.onosproject.net
MarkerResource to add hints about installable Intent.
markFullyStarted(boolean) - Method in interface org.onosproject.cluster.ClusterAdminService
Marks the current node as fully started or not.
markFullyStarted(boolean) - Method in interface org.onosproject.cluster.ClusterStore
Marks the current node as fully started.
markOffline(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Removes the specified infrastructure device.
markOnline(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Marks the device as available.
mask() - Method in class org.onosproject.net.flow.criteria.EthCriterion
Gets the mask for the MAC address to match.
mask() - Method in class org.onosproject.net.flow.criteria.SctpPortCriterion
Gets the mask for the SCTP port to match.
mask() - Method in class org.onosproject.net.flow.criteria.TcpPortCriterion
Gets the mask for the TCP port to match.
mask() - Method in class org.onosproject.net.flow.criteria.UdpPortCriterion
Gets the mask for the UDP port to match.
mask() - Method in class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
Returns the mask used to match this field.
master() - Method in class org.onosproject.cluster.RoleInfo
 
master() - Method in class org.onosproject.mastership.MastershipInfo
Returns the current master.
master() - Method in class org.onosproject.mastership.MastershipTerm
 
master() - Method in class org.onosproject.store.flow.ReplicaInfo
Returns the NodeId, if there is a Node where the master copy should be.
MASTER - org.onosproject.net.MastershipRole
Represents a relationship where the controller instance is the master to a device or a region of network environment.
MASTER_CHANGED - org.onosproject.mastership.MastershipEvent.Type
Signifies that the master for a device has changed.
MASTER_CHANGED - org.onosproject.store.flow.ReplicaInfoEvent.Type
Event to notify that master placement should be changed.
masters() - Method in class org.onosproject.net.region.DefaultRegion
 
masters() - Method in interface org.onosproject.net.region.Region
Returns the list of master node sets.
mastership() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a mastership service implementation.
MastershipAdminService - Interface in org.onosproject.mastership
Service for administering the inventory of device masterships.
MastershipBasedTimestampSerializer - Class in org.onosproject.store.serializers.custom
Kryo Serializer for MastershipBasedTimestamp.
MastershipBasedTimestampSerializer() - Constructor for class org.onosproject.store.serializers.custom.MastershipBasedTimestampSerializer
Creates a serializer for MastershipBasedTimestamp.
MastershipEvent - Class in org.onosproject.mastership
Describes a device mastership event.
MastershipEvent(MastershipEvent.Type, DeviceId, MastershipInfo) - Constructor for class org.onosproject.mastership.MastershipEvent
Creates an event of a given type and for the specified device, role information, and the current time.
MastershipEvent(MastershipEvent.Type, DeviceId, MastershipInfo, long) - Constructor for class org.onosproject.mastership.MastershipEvent
Creates an event of a given type and for the specified device, master, and time.
MastershipEvent.Type - Enum in org.onosproject.mastership
Type of mastership events.
mastershipInfo() - Method in class org.onosproject.mastership.MastershipEvent
Returns the mastership info.
MastershipInfo - Class in org.onosproject.mastership
Mastership info.
MastershipInfo() - Constructor for class org.onosproject.mastership.MastershipInfo
 
MastershipInfo(long, Optional<NodeId>, ImmutableMap<NodeId, MastershipRole>) - Constructor for class org.onosproject.mastership.MastershipInfo
 
MastershipListener - Interface in org.onosproject.mastership
Entity capable of receiving device mastership-related events.
MastershipProxyFactory<T> - Interface in org.onosproject.mastership
Mastership-based proxy factory.
MastershipProxyService - Interface in org.onosproject.mastership
Manages remote mastership-based proxy services and instances.
MastershipRole - Enum in org.onosproject.net
Representation of a relationship role of a controller instance to a device or a region of network environment.
MastershipService - Interface in org.onosproject.mastership
Service responsible for determining the controller instance mastership of a device in a clustered environment.
MastershipStore - Interface in org.onosproject.mastership
Manages inventory of mastership roles for devices, across controller instances; not intended for direct use.
MastershipStoreDelegate - Interface in org.onosproject.mastership
Mastership store delegate abstraction.
MastershipTerm - Class in org.onosproject.mastership
 
MastershipTermSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for MastershipTerm.
MastershipTermSerializer() - Constructor for class org.onosproject.store.serializers.MastershipTermSerializer
Creates MastershipTerm serializer instance.
MastershipTermService - Interface in org.onosproject.mastership
Service to obtain mastership term information.
MastersListCommand - Class in org.onosproject.cli
Lists device mastership information.
MastersListCommand() - Constructor for class org.onosproject.cli.MastersListCommand
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.ArpPacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.Dhcp6DirectPacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.Dhcp6IndirectPacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.DhcpPacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.Icmp6PacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.IcmpPacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.NAPacketClassifier
 
match(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.NSPacketClassifier
 
match(PacketContext) - Method in interface org.onosproject.net.packet.PacketInClassifier
Returns true if the packet classifier matches else false.
Match<T> - Class in org.onlab.util
Utility class for checking matching values.
matchArpOp(int) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on arp operation type field using the specified value.
matchArpOp(int) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchArpOp(int) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a arp operation type.
matchArpSha(MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on MAC source field using the specified value.
matchArpSha(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchArpSha(MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a arp_eth_src address.
matchArpSpa(Ip4Address) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv4 source field using the specified value.
matchArpSpa(Ip4Address) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchArpSpa(Ip4Address) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a arp IPv4 source address.
matchArpTha(MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on MAC destination field using the specified value.
matchArpTha(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchArpTha(MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a arp_eth_dst address.
matchArpTpa(Ip4Address) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv4 destination field using the specified value.
matchArpTpa(Ip4Address) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchArpTpa(Ip4Address) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a arp IPv4 destination address.
matches(T) - Method in class org.onlab.util.Match
Checks if this instance matches specified value.
matchesEncapped() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
True if this PDR matches on packets received with a GTP header, and false otherwise.
matchesUnencapped() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
True if this PDR matches on packets received without a GTP header, and false otherwise.
matchEthDst(MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ETH_DST field using the specified value.
matchEthDst(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchEthDst(MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l2 dst address.
matchEthDstMasked(MacAddress, MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on ETH_DST field using the specified value and mask.
matchEthDstMasked(MacAddress, MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchEthDstMasked(MacAddress, MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l2 dst address with mask.
matchEthSrc(MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ETH_SRC field using the specified value.
matchEthSrc(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchEthSrc(MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l2 src address.
matchEthSrcMasked(MacAddress, MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on ETH_SRC field using the specified value and mask.
matchEthSrcMasked(MacAddress, MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchEthSrcMasked(MacAddress, MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l2 src address with mask.
matchEthType(int) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ETH_TYPE field using the specified value.
matchEthType(short) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchEthType(short) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches the ethernet type.
matchEthType(EthType) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ETH_TYPE field using the specified value.
matchExact(PiMatchFieldId, byte[]) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an exact field match for the given fieldId and value.
matchExact(PiMatchFieldId, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an exact field match for the given fieldId and value.
matchExact(PiMatchFieldId, long) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an exact field match for the given fieldId and value.
matchExact(PiMatchFieldId, short) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an exact field match for the given fieldId and value.
matchExact(PiMatchFieldId, String) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an exact field match for the given fieldId and value.
matchField(PiMatchFieldId) - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns the match field model associated with the given ID, if present.
matchFields() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns the collection of match fields supported by this table.
matchIcmpCode(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIcmpCode(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an ICMP code.
matchIcmpCode(short) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ICMP code field using the specified value.
matchIcmpType(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIcmpType(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an ICMP type.
matchIcmpType(short) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ICMP type field using the specified value.
matchIcmpv6Code(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIcmpv6Code(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an ICMPv6 code.
matchIcmpv6Code(short) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ICMPv6 code field using the specified value.
matchIcmpv6Type(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIcmpv6Type(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an ICMPv6 type.
matchIcmpv6Type(short) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ICMPv6 type field using the specified value.
matchInnerVlanId(VlanId) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on the inner VLAN ID field using the specified value.
matchInnerVlanId(VlanId) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchInnerVlanId(VlanId) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches the inner vlan id.
matchInnerVlanPcp(byte) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on the inner VLAN PCP field using the specified value.
matchInnerVlanPcp(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchInnerVlanPcp(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a vlan priority.
matchInPhyPort(PortNumber) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IN_PHY_PORT field using the specified value.
matchInPhyPort(PortNumber) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchInPhyPort(PortNumber) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a physical inport.
matchInPort(PortNumber) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IN_PORT field using the specified value.
matchInPort(PortNumber) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchInPort(PortNumber) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an inport.
matchIPDscp(byte) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IP DSCP field using the specified value.
matchIPDscp(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPDscp(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an IP DSCP (6 bits in ToS field).
matchIPDst(IpPrefix) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv4 destination field using the specified value.
matchIPDst(IpPrefix) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPDst(IpPrefix) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l3 IPv4 address.
matchIPEcn(byte) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IP ECN field using the specified value.
matchIPEcn(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPEcn(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an IP ECN (2 bits in ToS field).
matchIPProtocol(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPProtocol(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches the l3 protocol.
matchIPProtocol(short) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IP proto field using the specified value.
matchIPSrc(IpPrefix) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv4 source field using the specified value.
matchIPSrc(IpPrefix) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPSrc(IpPrefix) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l3 IPv4 address.
matchIPv6Dst(IpPrefix) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 destination field using the specified value.
matchIPv6Dst(IpPrefix) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6Dst(IpPrefix) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l3 IPv6 address.
matchIPv6ExthdrFlags(int) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 Extension Header pseudo-field fiags.
matchIPv6ExthdrFlags(short) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6ExthdrFlags(short) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches on IPv6 Extension Header pseudo-field flags.
matchIPv6FlowLabel(int) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 flow label field using the specified value.
matchIPv6FlowLabel(int) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6FlowLabel(int) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an IPv6 flow label.
matchIPv6NDSourceLinkLayerAddress(MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 Neighbor Discovery source link-layer address using the specified value.
matchIPv6NDSourceLinkLayerAddress(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6NDSourceLinkLayerAddress(MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an IPv6 Neighbor Discovery source link-layer address.
matchIPv6NDTargetAddress(Ip6Address) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 Neighbor Discovery target address using the specified value.
matchIPv6NDTargetAddress(Ip6Address) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6NDTargetAddress(Ip6Address) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an IPv6 Neighbor Discovery target address.
matchIPv6NDTargetLinkLayerAddress(MacAddress) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 Neighbor Discovery target link-layer address using the specified value.
matchIPv6NDTargetLinkLayerAddress(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6NDTargetLinkLayerAddress(MacAddress) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an IPv6 Neighbor Discovery target link-layer address.
matchIPv6Src(IpPrefix) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on IPv6 source field using the specified value.
matchIPv6Src(IpPrefix) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchIPv6Src(IpPrefix) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a l3 IPv6 address.
matchKey() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
Returns the match key of this table entry.
matchKey() - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
Returns the match key associated with this handle.
matchLambda(Lambda) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on lambda using the specified value.
matchLpm(PiMatchFieldId, byte[], int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a longest-prefix field match for the given fieldId, value and prefix length.
matchLpm(PiMatchFieldId, int, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a longest-prefix field match for the given fieldId, value and prefix length.
matchLpm(PiMatchFieldId, long, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a longest-prefix field match for the given fieldId, value and prefix length.
matchLpm(PiMatchFieldId, short, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a longest-prefix field match for the given fieldId, value and prefix length.
matchMetadata(long) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on METADATA field using the specified value.
matchMetadata(long) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchMetadata(long) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a metadata.
matchMplsBos(boolean) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on MPLS Bottom-of-Stack indicator bit.
matchMplsBos(boolean) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchMplsBos(boolean) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches on a MPLS Bottom-of-Stack indicator bit.
matchMplsLabel(MplsLabel) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on MPLS label.
matchMplsLabel(MplsLabel) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchMplsLabel(MplsLabel) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches on a MPLS label.
matchMplsTc(byte) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on MPLS TC.
matchOchSignalType(OchSignalType) - Static method in class org.onosproject.net.flow.criteria.Criteria
Create a match on OCh (Optical Channel) signal type.
matchOduSignalId(OduSignalId) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ODU (Optical channel Data Unit) signal ID using the specified value.
matchOduSignalType(OduSignalType) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on ODU (Optical channel Data Unit) signal Type using the specified value.
matchOptional(PiMatchFieldId, byte[]) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an optional field match for the given fieldId and value.
matchOptional(PiMatchFieldId, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an optional field match for the given fieldId and value.
matchOptional(PiMatchFieldId, long) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an optional field match for the given fieldId and value.
matchOptional(PiMatchFieldId, short) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an optional field match for the given fieldId and value.
matchOptional(PiMatchFieldId, String) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds an optional field match for the given fieldId and value.
matchPbbIsid(int) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on PBB I-SID field using the specific value.
matchPi(PiCriterion) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchPi(PiCriterion) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches protocol independent fields.
matchQfi() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Returns whether QFI should be matched on the packet or not.
matchRange(PiMatchFieldId, byte[], byte[]) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a range field match for the given fieldId, low and high.
matchRange(PiMatchFieldId, int, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a range field match for the given fieldId, low and high.
matchRange(PiMatchFieldId, long, long) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a range field match for the given fieldId, low and high.
matchRange(PiMatchFieldId, short, short) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a range field match for the given fieldId, low and high.
matchSctpDst(TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on SCTP destination port field using the specified value.
matchSctpDst(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchSctpDst(TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a SCTP destination port number.
matchSctpDstMasked(TpPort, TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on SCTP destination port field using the specified value and mask.
matchSctpDstMasked(TpPort, TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchSctpDstMasked(TpPort, TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a SCTP destination port number with mask.
matchSctpSrc(TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on SCTP source port field using the specified value.
matchSctpSrc(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchSctpSrc(TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a SCTP source port number.
matchSctpSrcMasked(TpPort, TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on SCTP source port field using the specified value and mask.
matchSctpSrcMasked(TpPort, TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchSctpSrcMasked(TpPort, TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a SCTP source port number with mask.
matchString() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Return a string representing the match conditions of this PDR.
matchTcpDst(TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on TCP destination port field using the specified value.
matchTcpDst(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchTcpDst(TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a TCP destination port number.
matchTcpDstMasked(TpPort, TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on TCP destination port field using the specified value and mask.
matchTcpDstMasked(TpPort, TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchTcpDstMasked(TpPort, TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a TCP destination port number with mask.
matchTcpFlags(int) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on TCP flags using the specified value.
matchTcpSrc(TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on TCP source port field using the specified value.
matchTcpSrc(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchTcpSrc(TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a TCP source port number.
matchTcpSrcMasked(TpPort, TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on TCP source port field using the specified value and mask.
matchTcpSrcMasked(TpPort, TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchTcpSrcMasked(TpPort, TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a TCP source port number with mask.
matchTernary(PiMatchFieldId, byte[], byte[]) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a ternary field match for the given fieldId, value and mask.
matchTernary(PiMatchFieldId, int, int) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a ternary field match for the given fieldId, value and mask.
matchTernary(PiMatchFieldId, long, long) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a ternary field match for the given fieldId, value and mask.
matchTernary(PiMatchFieldId, short, short) - Method in class org.onosproject.net.flow.criteria.PiCriterion.Builder
Adds a ternary field match for the given fieldId, value and mask.
matchTunnelId(long) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on Tunnel ID.
matchTunnelId(long) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchTunnelId(long) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a tunnel id.
matchType() - Method in interface org.onosproject.net.pi.model.PiMatchFieldModel
Returns the type of match applied to this field.
matchUdpDst(TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on UDP destination port field using the specified value.
matchUdpDst(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchUdpDst(TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an UDP destination port number.
matchUdpDstMasked(TpPort, TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on UDP destination port field using the specified value and mask.
matchUdpDstMasked(TpPort, TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchUdpDstMasked(TpPort, TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a UDP destination port number with mask.
matchUdpSrc(TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on UDP source port field using the specified value.
matchUdpSrc(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchUdpSrc(TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches an UDP source port number.
matchUdpSrcMasked(TpPort, TpPort) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a masked match on UDP source port field using the specified value and mask.
matchUdpSrcMasked(TpPort, TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchUdpSrcMasked(TpPort, TpPort) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a UDP source port number with mask.
matchVlanId(VlanId) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on VLAN ID field using the specified value.
matchVlanId(VlanId) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchVlanId(VlanId) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches the vlan id.
matchVlanPcp(byte) - Static method in class org.onosproject.net.flow.criteria.Criteria
Creates a match on VLAN PCP field using the specified value.
matchVlanPcp(byte) - Method in class org.onosproject.net.flow.DefaultTrafficSelector.Builder
 
matchVlanPcp(byte) - Method in interface org.onosproject.net.flow.TrafficSelector.Builder
Matches a vlan priority.
max(C, C) - Static method in class org.onlab.util.Tools
Returns larger of the two Comparable values.
max(Path) - Method in interface org.onosproject.net.statistic.StatisticService
Find the most loaded link along a path.
MAX - org.onosproject.net.behaviour.QueueDescription.Type
Support max rate.
MAX - org.onosproject.net.packet.PacketPriority
Other choices for applications.
MAX - Static variable in class org.onosproject.net.meter.MeterId
Flow meters can use any number up to MAX.
MAX_ATTR_VALUE_LENGTH - Static variable in class org.onlab.packet.RADIUS
 
MAX_BACKUP_COUNT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
MAX_BACKUP_COUNT_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
MAX_BUFFER_SIZE - Static variable in class org.onlab.util.KryoNamespace
 
MAX_DSCP - Static variable in class org.onosproject.net.behaviour.DefaultQueueDescription
 
MAX_DSCP - Static variable in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Upper bound for DSCP.
MAX_EVENT_TIME_LIMIT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MAX_EVENT_TIME_LIMIT_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MAX_INET_MASK_LENGTH - Static variable in class org.onlab.packet.IpPrefix
Longest IPv4 network prefix.
MAX_INET6_MASK_LENGTH - Static variable in class org.onlab.packet.IpPrefix
Longest IPv6 network prefix.
MAX_INFOSTRING_LENGTH - Static variable in class org.onlab.packet.LLDPOrganizationalTLV
 
MAX_LENGTH - Static variable in class org.onlab.packet.LLDPTLV
 
MAX_MASK_LENGTH - Static variable in class org.onlab.packet.Ip4Prefix
 
MAX_MASK_LENGTH - Static variable in class org.onlab.packet.Ip6Prefix
 
MAX_MPLS - Static variable in class org.onlab.packet.MplsLabel
 
MAX_PATHS - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
MAX_PATHS_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
MAX_PORT - Static variable in class org.onlab.packet.TpPort
 
MAX_PRECEDENCE - Static variable in interface org.onosproject.net.meter.Band
 
MAX_PRIORITY - Static variable in interface org.onosproject.net.flow.FlowRule
 
MAX_PRIORITY - Static variable in interface org.onosproject.net.flowobjective.Objective
 
MAX_PRIORITY - Static variable in class org.onosproject.net.intent.Intent
 
MAX_TIMEOUT - Static variable in interface org.onosproject.net.flow.FlowRule
 
MAX_VLAN - Static variable in class org.onlab.packet.VlanId
 
maxBands() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
maxBands() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns the maximum bands per meter.
maxBatchMillis() - Method in class org.onlab.util.AbstractAccumulator
Returns the maximum number of millis allowed to expire since the first item before processing is triggered.
maxColor() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
maxColor() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns the maximum colors value for DiffServ operation.
maxGroupSize() - Method in interface org.onosproject.net.pi.model.PiActionProfileModel
Returns the maximum number of members a group of this action profile can hold.
maxIdleMillis() - Method in class org.onlab.util.AbstractAccumulator
Returns the maximum number of millis allowed to expire since the last item arrival before processing is triggered.
MAXIMALLY - org.onosproject.ui.topo.Highlights.Amount
 
maxItems() - Method in class org.onlab.util.AbstractAccumulator
Returns the maximum number of items allowed to accumulate before processing is triggered.
maxLen() - Method in class org.onosproject.net.flow.instructions.Instructions.TruncateInstruction
 
maxMeter() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
maxMeter() - Method in interface org.onosproject.net.meter.MeterFeatures
Deprecated.
maxMetric(String) - Method in interface org.onosproject.cpman.MetricsDatabase
Returns maximum metric value of a given metric type.
maxPacketLengthBytes() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
Returns the maximum length in bytes of cloned packets.
maxPaths - Variable in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
maxPriority(ThreadFactory) - Static method in class org.onlab.util.Tools
Returns a thread factory that produces threads with MAX_PRIORITY.
maxRate() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
maxRate() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
maxRate() - Method in interface org.onosproject.net.behaviour.QosDescription
Returns the max rate of qos, Valid only in specific qos type.
maxRate() - Method in interface org.onosproject.net.behaviour.QueueDescription
Returns max rate, Valid only in specific type.
maxRate(Bandwidth) - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
 
maxRate(Bandwidth) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
 
maxRate(Bandwidth) - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
Returns qos description builder with given maxRate.
maxRate(Bandwidth) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
Returns queue description builder with max rate.
maxSize() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
maxSize() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
Returns the maximum size of this table.
maxSize() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns the maximum number of entries supported by this table.
maxSize() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
Returns the maximum number of members that this group can hold.
MB_PER_SEC - org.onosproject.net.behaviour.trafficcontrol.Policer.Unit
MByte per second.
mbps(double) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in Mbps.
mbps(long) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in Mbps.
mBps(double) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in MBps.
mBps(long) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth in MBps.
MBPS - org.onlab.util.DataRateUnit
Megabit per second.
MCAST_DONE - org.onosproject.cli.net.Icmp6Type
Multicast Listener Done.
MCAST_DONE - Static variable in class org.onlab.packet.ICMP6
Multicast Listener Done.
MCAST_QUERY - org.onosproject.cli.net.Icmp6Type
Multicast Listener Query.
MCAST_QUERY - Static variable in class org.onlab.packet.ICMP6
Multicast Listener Query.
MCAST_REPORT - org.onosproject.cli.net.Icmp6Type
Multicast Listener Report.
MCAST_REPORT - Static variable in class org.onlab.packet.ICMP6
Multicast Listener Report.
McastConfig - Class in org.onosproject.net.config.basics
Configuration for multicast.
McastConfig() - Constructor for class org.onosproject.net.config.basics.McastConfig
 
McastDeleteCommand - Class in org.onosproject.cli.net
Deletes a multicast route.
McastDeleteCommand() - Constructor for class org.onosproject.cli.net.McastDeleteCommand
 
McastEvent - Class in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
McastEvent(McastEvent.Type, McastRouteInfo) - Constructor for class org.onosproject.net.mcast.McastEvent
Deprecated.
Creates a McastEvent of a given type using the subject.
McastEvent(McastEvent.Type, McastRouteInfo, McastRouteInfo) - Constructor for class org.onosproject.net.mcast.McastEvent
Deprecated.
Creates a McastEvent of a given type using the subject and the previous subject.
McastEvent.Type - Enum in org.onosproject.net.mcast
Deprecated.
 
McastGroupCompleter - Class in org.onosproject.cli.net
Mcast group Completer.
McastGroupCompleter() - Constructor for class org.onosproject.cli.net.McastGroupCompleter
 
McastJoinCommand - Class in org.onosproject.cli.net
Installs a source, multicast group flow.
McastJoinCommand() - Constructor for class org.onosproject.cli.net.McastJoinCommand
 
McastListener - Interface in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
McastRoute - Class in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
McastRoute(IpAddress, IpAddress, McastRoute.Type) - Constructor for class org.onosproject.net.mcast.McastRoute
Deprecated.
 
McastRoute.Type - Enum in org.onosproject.net.mcast
Deprecated.
 
mcastRouteInfo(McastRoute) - Static method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
 
mcastRouteInfo(McastRoute, Set<ConnectPoint>, ConnectPoint) - Static method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
 
mcastRouteInfo(McastRoute, ConnectPoint, ConnectPoint) - Static method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
 
McastRouteInfo - Class in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
McastRoutesListCommand - Class in org.onosproject.cli.net
Displays the source, multicast group flows entries.
McastRoutesListCommand() - Constructor for class org.onosproject.cli.net.McastRoutesListCommand
 
McastShowCommand - Class in org.onosproject.cli.net
Displays the source, multicast group flows entries.
McastShowCommand() - Constructor for class org.onosproject.cli.net.McastShowCommand
 
mcastSnoopingEnable() - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
Returns bridge description builder with mcast snooping enabled.
mcastSnoopingEnable() - Method in interface org.onosproject.net.behaviour.BridgeDescription
Returns multicast snooping is enabled or not.
mcastSnoopingEnable() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
 
mcastSnoopingEnable() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
 
McastStore - Interface in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
McastStore.Type - Enum in org.onosproject.net.mcast
Deprecated.
 
McastStoreDelegate - Interface in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
MEDIUM - org.onosproject.net.packet.PacketPriority
 
MEGA - org.onosproject.ui.topo.TopoUtils.Magnitude
 
member(PiActionProfileMemberId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
Returns the group member identified by the given action profile member ID, if present.
Member - Class in org.onosproject.cluster
Controller member identity.
Member(NodeId, Version) - Constructor for class org.onosproject.cluster.Member
Creates a new cluster member identifier from the specified string.
MemberDetails(byte[], int) - Constructor for class org.onlab.packet.EAPOLMkpduPeerListParameterSet.MemberDetails
 
memberExists(byte[]) - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
Searching Member details.
memberId() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
Returns the member ID of this handle.
members - Variable in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
 
members() - Method in class org.onosproject.cluster.MembershipGroup
Returns the set of members in the group.
members() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
Returns the list of member references of this action profile group.
members() - Method in class org.onosproject.store.service.PartitionInfo
Returns the list of partition members.
MEMBERSHIP_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
MembershipGroup - Class in org.onosproject.cluster
Membership group.
MembershipGroup(Version, Set<Member>) - Constructor for class org.onosproject.cluster.MembershipGroup
 
MembershipService - Interface in org.onosproject.cluster
Service for obtaining information about the individual members of the controller cluster.
MembershipsListCommand - Class in org.onosproject.cli
Command to list the memberships in the system.
MembershipsListCommand() - Constructor for class org.onosproject.cli.MembershipsListCommand
 
memo() - Method in class org.onosproject.ui.model.topo.UiModelEvent
Returns the memo.
MEMORY - org.onosproject.cpman.ControlResource.Type
 
MEMORY_FREE - org.onosproject.cpman.ControlMetricType
 
MEMORY_FREE_RATIO - org.onosproject.cpman.ControlMetricType
 
MEMORY_METRICS - Static variable in class org.onosproject.cpman.ControlResource
 
MEMORY_TOTAL - org.onosproject.cpman.ControlMetricType
 
MEMORY_USED - org.onosproject.cpman.ControlMetricType
 
MEMORY_USED_RATIO - org.onosproject.cpman.ControlMetricType
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
merge(Weight) - Method in class org.onlab.graph.ScalarWeight
 
merge(Weight) - Method in interface org.onlab.graph.Weight
Merges the given weight with this one returning a new aggregated weight.
merge(DefaultAnnotations, SparseAnnotations) - Static method in class org.onosproject.net.DefaultAnnotations
Merges the specified base set of annotations and additional sparse annotations into new combined annotations.
merge(Driver) - Method in class org.onosproject.net.driver.DefaultDriver
 
merge(Driver) - Method in interface org.onosproject.net.driver.Driver
Merges the specified driver behaviours and properties into this one, giving preference to the other driver when dealing with conflicts.
message() - Method in class org.onosproject.ui.topo.NodeBadge
Returns the message associated with the badge.
MESSAGE - Static variable in class org.onlab.junit.ExceptionTest
 
MESSAGE_HANDLER_THREAD_POOL_SIZE - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
MESSAGE_HANDLER_THREAD_POOL_SIZE_DEFAULT - Static variable in class org.onosproject.store.OsgiPropertyConstants
 
messageFrom(Throwable) - Method in class org.onlab.rest.exceptions.AbstractMapper
Produces a response message from the supplied exception.
messageHandlerFactory() - Method in class org.onosproject.ui.UiExtension
Returns message handler factory, if one was defined.
messageHandlerFactory(UiMessageHandlerFactory) - Method in class org.onosproject.ui.UiExtension.Builder
Sets the message handler factory for this extension.
MessageSubject - Class in org.onosproject.store.cluster.messaging
Representation of a message subject.
MessageSubject() - Constructor for class org.onosproject.store.cluster.messaging.MessageSubject
 
MessageSubject(String) - Constructor for class org.onosproject.store.cluster.messaging.MessageSubject
 
messageTypes() - Method in class org.onosproject.ui.UiMessageHandler
Returns the set of message types which this handler is capable of processing.
MessagingException - Exception in org.onosproject.store.cluster.messaging
Top level exception for MessagingService failures.
MessagingException() - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException
 
MessagingException(String) - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException
 
MessagingException(String, Throwable) - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException
 
MessagingException(Throwable) - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException
 
MessagingException.NoRemoteHandler - Exception in org.onosproject.store.cluster.messaging
Exception indicating no remote registered remote handler.
MessagingException.ProtocolException - Exception in org.onosproject.store.cluster.messaging
Exception indicating failure due to invalid message structure such as an incorrect preamble.
MessagingException.RemoteHandlerFailure - Exception in org.onosproject.store.cluster.messaging
Exception indicating handler failure.
MessagingService - Interface in org.onosproject.store.cluster.messaging
Interface for low level messaging primitives.
meta() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
meta() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
meta() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
meta() - Method in interface org.onosproject.net.flowobjective.FilteringObjective
Auxiliary optional information provided to the device driver.
meta() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective
Auxiliary optional information provided to the device driver.
meta() - Method in interface org.onosproject.net.flowobjective.NextObjective
Auxiliary optional information provided to the device driver.
metadata() - Method in class org.onosproject.net.flow.criteria.MetadataCriterion
Gets the metadata to match.
metadata() - Method in class org.onosproject.net.flow.instructions.Instructions.MetadataInstruction
 
metadata() - Method in class org.onosproject.net.PipelineTraceablePacket
Getter for the metadata.
METADATA - org.onosproject.net.flow.criteria.Criterion.Type
Metadata passed between tables.
METADATA - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that metadata be attached to traffic.
METADATA_CHANGED - org.onosproject.cluster.ClusterMetadataEvent.Type
Signifies that the cluster metadata has changed.
MetadataCriterion - Class in org.onosproject.net.flow.criteria
Implementation of Metadata criterion.
metadataMask() - Method in class org.onosproject.net.flow.instructions.Instructions.MetadataInstruction
 
metadatas() - Method in interface org.onosproject.net.pi.model.PiPacketOperationModel
Returns a list of packet metadata models for this packet operation.
metadatas() - Method in class org.onosproject.net.pi.runtime.PiPacketOperation
Returns all metadatas of this packet.
metadataTypes() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective
Returns a set of metadata types specified in this objective.
meter() - Method in class org.onosproject.net.meter.MeterOperation
Returns the meter.
meter(MeterId) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
meter(MeterId) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets a meter to be used by this flow.
meter(PiMeterId) - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns the meter model associated with the given ID, if present.
Meter - Interface in org.onosproject.net.meter
Represents a generalized meter cell configuration to be deployed on a device.
METER - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that traffic should be metered according to a meter.
METER_ADD_REQ - org.onosproject.net.meter.MeterEvent.Type
A meter addition was requested.
METER_ADDED - org.onosproject.net.meter.MeterEvent.Type
A meter was finally added to device.
METER_CAPABLE - Static variable in interface org.onosproject.net.meter.MeterProvider
Meter capable property name.
METER_CELL_CONFIG - org.onosproject.net.pi.runtime.PiEntityType
Meter cell config.
METER_DELETE - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
METER_GLOBAL_SCOPE - Static variable in class org.onosproject.net.meter.MeterScope
 
METER_REFERENCE_COUNT_ZERO - org.onosproject.net.meter.MeterEvent.Type
Meter is not used by any flow.
METER_REM_REQ - org.onosproject.net.meter.MeterEvent.Type
A meter removal was requested.
METER_REMOVED - org.onosproject.net.meter.MeterEvent.Type
A meter was finally removed from device.
METER_TABLE - Static variable in class org.onosproject.ui.GlyphConstants
 
Meter.Builder - Interface in org.onosproject.net.meter
A meter builder.
Meter.Unit - Enum in org.onosproject.net.meter
 
MeterAddCommand - Class in org.onosproject.cli.net
Add a meter to a device.
MeterAddCommand() - Constructor for class org.onosproject.cli.net.MeterAddCommand
 
meterBands() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
Returns the map of bands of this cell.
meterCellId() - Method in class org.onosproject.net.meter.DefaultMeter
 
meterCellId() - Method in interface org.onosproject.net.meter.Meter
Returns the meter cell identifier of this meter.
meterCellId() - Method in class org.onosproject.net.meter.MeterKey
 
MeterCellId - Interface in org.onosproject.net.meter
A representation of a meter cell identifier.
MeterCellId.MeterCellType - Enum in org.onosproject.net.meter
Types of meter cell identifier.
MeterContext - Interface in org.onosproject.net.meter
A context permitting the application to be notified when the meter installation has been successful.
metered() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
metered() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the meter instruction if there is one.
METERED - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for identifying a metered link.
METERED_USAGE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for data usage on a metered link.
METERED_USAGE - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
MeteredConstraint - Class in org.onosproject.net.intent.constraint
Constraint that evaluates links based on the metered flag.
MeteredConstraint(boolean) - Constructor for class org.onosproject.net.intent.constraint.MeteredConstraint
Creates a new constraint for requesting connectivity using or avoiding the metered links.
meteredUsage() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns metered link usage in terms of percentage.
meteredUsage(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the metered link usage.
MeterEntry - Interface in org.onosproject.net.meter
Represents a stored meter.
MeterEvent - Class in org.onosproject.net.meter
Entity that represents Meter events.
MeterEvent(MeterEvent.Type, Meter) - Constructor for class org.onosproject.net.meter.MeterEvent
Creates an event of a given type and for the specified meter and the current time.
MeterEvent(MeterEvent.Type, Meter, long) - Constructor for class org.onosproject.net.meter.MeterEvent
Creates an event of a given type and for the specified meter and time.
MeterEvent.Type - Enum in org.onosproject.net.meter
 
MeterFailReason - Enum in org.onosproject.net.meter
Enum used to represent a meter failure condition.
MeterFeatures - Interface in org.onosproject.net.meter
Meter Features of a device.
MeterFeatures.Builder - Interface in org.onosproject.net.meter
A meter features builder.
MeterFeaturesFlag - Enum in org.onosproject.net.meter
 
MeterFeaturesKey - Class in org.onosproject.net.meter
Deprecated.
in onos-2.5 replaced by MeterTableKey
meterId() - Method in class org.onosproject.net.flow.instructions.Instructions.MeterInstruction
 
meterId() - Method in class org.onosproject.net.meter.MeterKey
Deprecated.
in onos-2.5 replaced by MeterKey.key(DeviceId,MeterCellId) extends MeterKey to support both MeterId and PiMeterCellId
meterId() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
Returns the identifier of the meter instance where this cell is contained.
meterId(long) - Static method in class org.onosproject.net.meter.MeterId
Creates a new meter identifier.
MeterId - Class in org.onosproject.net.meter
A representation of a meter cell identifier.
MeteringAgent - Class in org.onosproject.utils
Agent that implements usage and performance monitoring via the metrics service.
MeteringAgent(String, String, boolean) - Constructor for class org.onosproject.utils.MeteringAgent
Constructs a new MeteringAgent for a given distributed primitive.
MeteringAgent.Context - Class in org.onosproject.utils
Timer.Context with a specific operation.
meteringEnabled() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns if metering is enabled.
MeterKey - Class in org.onosproject.net.meter
A meter key represents a meter uniquely.
MeterListener - Interface in org.onosproject.net.meter
Entity capable of receiving Meter related events.
MeterOperation - Class in org.onosproject.net.meter
Representation of an operation on the meter table.
MeterOperation(Meter, MeterOperation.Type) - Constructor for class org.onosproject.net.meter.MeterOperation
 
MeterOperation.Type - Enum in org.onosproject.net.meter
Tyoe of meter operation.
meterOperationFailed(MeterOperation, MeterFailReason) - Method in interface org.onosproject.net.meter.MeterProviderService
Notifies the core that a meter operaton failed for a specific reason.
MeterOperations - Class in org.onosproject.net.meter
Immutable collection of meter operation to be used between core and provider layers of group subsystem.
MeterOperations(List<MeterOperation>) - Constructor for class org.onosproject.net.meter.MeterOperations
Creates a immutable list of meter operation.
MeterProgrammable - Interface in org.onosproject.net.meter
Meter programmable device behaviour.
MeterProvider - Interface in org.onosproject.net.meter
Abstraction of a Meter provider.
MeterProviderRegistry - Interface in org.onosproject.net.meter
Abstraction for a meter provider registry.
MeterProviderService - Interface in org.onosproject.net.meter
Service through which meter providers can inject information into the core.
MeterQuery - Interface in org.onosproject.net.behaviour
A HandlerBehaviour to check the capability of Meter.
MeterRemoveCommand - Class in org.onosproject.cli.net
Remove existing meter from device.
MeterRemoveCommand() - Constructor for class org.onosproject.cli.net.MeterRemoveCommand
 
MeterRequest - Interface in org.onosproject.net.meter
Represents a generalized meter request to be deployed on a device.
MeterRequest.Builder - Interface in org.onosproject.net.meter
A meter builder.
MeterRequest.Type - Enum in org.onosproject.net.meter
 
meters() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
meters() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the meter instructions if there is any.
meters() - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns all meter models defined by this pipeline model.
meters() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns a collection of direct meters associated to this table.
MeterScope - Class in org.onosproject.net.meter
Scope of Meter Features.
MeterService - Interface in org.onosproject.net.meter
Service for add/updating and removing meters.
MetersListCommand - Class in org.onosproject.cli.net
Lists all meters.
MetersListCommand() - Constructor for class org.onosproject.cli.net.MetersListCommand
 
MeterState - Enum in org.onosproject.net.meter
Represents the state of the meter as seen by the store.
MeterStore - Interface in org.onosproject.net.meter
Entity that stores and distributed meter objects.
MeterStoreDelegate - Interface in org.onosproject.net.meter
Meter store delegate abstraction.
MeterStoreResult - Class in org.onosproject.net.meter
An entity used to indicate whether the store operation passed.
MeterStoreResult.Type - Enum in org.onosproject.net.meter
 
MeterTableKey - Class in org.onosproject.net.meter
MeterTableKey is used to represent a single meter table in each device uniquely.
meterTraffic(MeterId) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a meter instruction.
meterTranslator() - Method in interface org.onosproject.net.pi.service.PiTranslationService
Returns a meter translator.
meterType() - Method in interface org.onosproject.net.pi.model.PiMeterModel
Returns the type of this meter.
meterType() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
Returns the type of the meter identified.
metric - Variable in class org.onlab.packet.RIPngEntry
 
metric - Variable in class org.onlab.packet.RIPV2Entry
 
metric() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link metric value for use by MetricLinkWeight function.
metric(Double) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link metric for use by MetricLinkWeight function.
METRIC - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for link metric; used by MetricLinkWeight function.
METRIC - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
MetricLinkWeight - Class in org.onosproject.net.topology
Link weight for measuring link cost using the link metric annotation.
MetricLinkWeight() - Constructor for class org.onosproject.net.topology.MetricLinkWeight
 
metricName() - Method in interface org.onosproject.cpman.MetricsDatabase
Returns the metric name of this database.
MetricNameCompleter - Class in org.onosproject.cli
Metric name completer.
MetricNameCompleter() - Constructor for class org.onosproject.cli.MetricNameCompleter
 
metrics(String) - Method in interface org.onosproject.cpman.MetricsDatabase
Returns a collection of metric values of a given metric type for a day.
metrics(String, long, long) - Method in interface org.onosproject.cpman.MetricsDatabase
Returns a collection of metric values of a given metric type for a given period.
MetricsComponent - Class in org.onlab.metrics
Components to register for metrics.
MetricsComponent(String) - Constructor for class org.onlab.metrics.MetricsComponent
Constructs a component from a name.
MetricsComponentRegistry - Interface in org.onlab.metrics
Registry Entry for Metrics Components.
MetricsDatabase - Interface in org.onosproject.cpman
Database for storing a metric.
MetricsDatabase.Builder - Interface in org.onosproject.cpman
A builder of MetricsDatabase.
MetricsFeature - Class in org.onlab.metrics
Features to tag metrics.
MetricsFeature(String) - Constructor for class org.onlab.metrics.MetricsFeature
Constructs a Feature from a name.
MetricsHelper - Interface in org.onosproject.core
Collection of utility methods used for providing Metrics.
MetricsListCommand - Class in org.onosproject.cli
Prints metrics in the system.
MetricsListCommand() - Constructor for class org.onosproject.cli.MetricsListCommand
 
MetricsManager - Class in org.onlab.metrics
This class holds the Metrics registry for ONOS.
MetricsManager() - Constructor for class org.onlab.metrics.MetricsManager
 
MetricsReporter - Interface in org.onlab.metrics
Interface of reporter that reports all metrics value to third party monitor.
metricsService() - Method in interface org.onosproject.core.MetricsHelper
Returns MetricService instance.
MetricsService - Interface in org.onlab.metrics
Metrics Service to collect metrics.
MetricsUtil - Class in org.onlab.metrics
 
metricType() - Method in class org.onosproject.cpman.ControlMetric
Returns metric type reference.
metricValue() - Method in class org.onosproject.cpman.ControlMetric
Returns metric value reference.
MetricValue - Class in org.onosproject.cpman
Primitive Metric Value.
MetricValue.Builder - Class in org.onosproject.cpman
MetricValue builder class.
METRO - org.onosproject.net.region.Region.Type
Region represents a metropolitan area.
mFlag - Variable in class org.onlab.packet.ndp.RouterAdvertisement
 
microseconds - Variable in class org.onlab.packet.bmp.BmpPeer
 
MICROWAVE - org.onosproject.net.Device.Type
 
MICROWAVE - Static variable in class org.onosproject.ui.GlyphConstants
 
MID - org.onosproject.net.flow.FlowEntry.FlowLiveType
Indicates that this rule has been submitted for a mid time.
MID_FLOW - org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Indicates that this rule has been submitted for a mid time.
midLoad() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Returns mid load of connect point.
min(C, C) - Static method in class org.onlab.util.Tools
Returns smaller of the two Comparable values.
min(Path) - Method in interface org.onosproject.net.statistic.StatisticService
Find the least loaded link along a path.
MIN - org.onosproject.net.behaviour.QueueDescription.Type
Support min rate.
MIN_DSCP - Static variable in class org.onosproject.net.behaviour.DefaultQueueDescription
 
MIN_DSCP - Static variable in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Lower bound for DSCP.
MIN_HEADER_LENGTH - Static variable in class org.onlab.packet.DHCP
Dynamic Host Configuration Protocol packet.
MIN_HEADER_LENGTH - Static variable in class org.onlab.packet.RIP
Routing Information Protocol packet.
MIN_HEADER_LENGTH - Static variable in class org.onlab.packet.RIPng
Routing Information Protocol Next Generation packet.
MIN_LEN - Static variable in class org.onlab.packet.EAP
 
MIN_PORT - Static variable in class org.onlab.packet.TpPort
 
MIN_PRECEDENCE - Static variable in interface org.onosproject.net.meter.Band
 
MIN_PRIORITY - Static variable in interface org.onosproject.net.flow.FlowRule
 
MIN_PRIORITY - Static variable in interface org.onosproject.net.flowobjective.Objective
 
MIN_PRIORITY - Static variable in class org.onosproject.net.intent.Intent
 
minFlowHopLatencyChangeNs() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
Returns the minimal interval of hop latency change for a flow.
minFlowHopLatencyChangeNs() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Gets the minimal interval of hop latency change for a flow.
MINIMALLY - org.onosproject.ui.topo.Highlights.Amount
 
MINIMUM_HEADER_LEN - Static variable in class org.onlab.packet.IGMP.IGMPv3
 
MINIMUM_OPTION_LEN_BYTES - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
minMetric(String) - Method in interface org.onosproject.cpman.MetricsDatabase
Returns minimum metric value of a given metric type.
minor() - Method in class org.onosproject.core.Version
Returns the minor version number.
MINOR - org.onosproject.alarm.Alarm.SeverityLevel
From X.733: This indicates the existence of a non-service affecting fault condition and that corrective action should be taken in order to prevent a more serious (for example, service affecting) fault.
minPriority(ThreadFactory) - Static method in class org.onlab.util.Tools
Returns a thread factory that produces threads with MIN_PRIORITY.
minRate() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
minRate() - Method in interface org.onosproject.net.behaviour.QueueDescription
Returns min rate, Valid only in specific type.
minRate(Bandwidth) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
 
minRate(Bandwidth) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
Returns queue description builder with a given min rate.
MINUS - Static variable in class org.onlab.packet.ipv6.Authentication
 
MINUS - Static variable in class org.onosproject.ui.GlyphConstants
 
MirroringConfig - Interface in org.onosproject.net.behaviour
Behaviour for handling various drivers for mirroring configurations.
MirroringDescription - Interface in org.onosproject.net.behaviour
The abstraction of a mirroring.
mirroringName(String) - Static method in class org.onosproject.net.behaviour.MirroringName
Creates a mirroring name using the supplied string.
MirroringName - Class in org.onosproject.net.behaviour
Represents for a mirroring name.
mirroringStatistics(String, Map<String, Integer>) - Static method in class org.onosproject.net.behaviour.MirroringStatistics
Creates a MirroringStatistics using the supplied information.
MirroringStatistics - Class in org.onosproject.net.behaviour
Represents statistics associated to a mirroring.
mirrorPort() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
Returns mirror port.
mirrorPort() - Method in interface org.onosproject.net.behaviour.MirroringDescription
Returns mirror port.
mirrorVlan() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
Returns mirror vlan.
mirrorVlan() - Method in interface org.onosproject.net.behaviour.MirroringDescription
Returns mirror vlan.
MISC - 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.
MISC_MAX_SIZE - Static variable in class org.onosproject.store.serializers.KryoNamespaces
KryoNamespace which can serialize ONF misc classes.
MM_FALLBACK_METER_POLL_FREQUENCY - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_FALLBACK_METER_POLL_FREQUENCY_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_NUM_THREADS - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_NUM_THREADS_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_PURGE_ON_DISCONNECTION - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_PURGE_ON_DISCONNECTION_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_USER_DEFINED_INDEX - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
MM_USER_DEFINED_INDEX_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
Mod - Class in org.onosproject.ui.topo
Highlighting modification.
Mod(String) - Constructor for class org.onosproject.ui.topo.Mod
Constructs a mod with the given identifier.
MOD_ANIMATED - Static variable in class org.onosproject.ui.topo.LinkHighlight
Denotes a link to be tagged with animated traffic ("marching ants").
MOD_OPTICAL - Static variable in class org.onosproject.ui.topo.LinkHighlight
Denotes a link to be tagged as an optical link.
modArpSha(MacAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a l3 ARP Ether src modification.
modArpSpa(IpAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 ARP IP src modification.
modArpTha(MacAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a l3 ARP Ether src modification.
modArpTpa(IpAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 ARP IP src modification.
mode() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
Returns the operation mode of the interface.
mode() - Method in interface org.onosproject.net.device.DeviceInterfaceDescription
Returns the operation mode of the interface.
mode() - Method in interface org.onosproject.net.host.HostProbe
Gets mode of this entry.
MODE_IS_EXCLUDE - Static variable in class org.onlab.packet.IGMPMembership
 
MODE_IS_INCLUDE - Static variable in class org.onlab.packet.IGMPMembership
 
model() - Method in class org.onosproject.rest.ApiDocProvider
Returns input stream containing JSON model schema.
modify() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
modify() - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Build the next objective that will be modified with Objective.Operation MODIFY.
modify(FlowRule) - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
Appends a flow rule modify to the current stage.
modify(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
modify(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Build the next objective that will be modified, with Objective.Operation MODIFY.
MODIFY - org.onosproject.net.flow.FlowRuleOperation.Type
 
MODIFY - org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry.FlowRuleOperation
Deprecated.
 
MODIFY - org.onosproject.net.flowobjective.Objective.Operation
Modify an existing Next Objective.
MODIFY - org.onosproject.net.group.GroupOperation.Type
Modify a group in a device with the specified parameters.
MODIFY - org.onosproject.net.meter.MeterOperation.Type
 
MODIFY - org.onosproject.net.meter.MeterRequest.Type
 
modifyDeviceDetails(PropertyPanel, DeviceId) - Method in class org.onosproject.ui.UiTopoOverlay
Callback to modify the contents of the details panel for a selected device.
modifyEdgeLinkDetails(PropertyPanel, HostId, ConnectPoint) - Method in class org.onosproject.ui.UiTopoOverlay
Callback to modify the contents of the details panel for a selected edge link.
modifyHostDetails(PropertyPanel, HostId) - Method in class org.onosproject.ui.UiTopoOverlay
Callback to modify the contents of the details panel for a selected host.
modifyInfraLinkDetails(PropertyPanel, ConnectPoint, ConnectPoint) - Method in class org.onosproject.ui.UiTopoOverlay
Callback to modify the contents of the details panel for a selected infrastructure link.
modifySummary(PropertyPanel) - Method in class org.onosproject.ui.UiTopoOverlay
Callback to modify the contents of the summary panel.
modIpDscp(byte) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates an IP DSCP modification.
modL0Lambda(Lambda) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates an L0 modification with the specified OCh signal.
modL1OduSignalId(OduSignalId) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates an L1 modification with the specified ODU signal Id.
modL2Dst(MacAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L2 dst modification.
modL2Src(MacAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a l2 src modification.
modL3ArpOp(short) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a l3 ARP operation modification.
modL3Dst(IpAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 IPv4 dst modification.
modL3IPv6Dst(IpAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 IPv6 dst modification.
modL3IPv6FlowLabel(int) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 IPv6 Flow Label modification.
modL3IPv6Src(IpAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 IPv6 src modification.
modL3Src(IpAddress) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a L3 IPv4 src modification.
modMplsBos(boolean) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a MPLS BOS bit modification.
modMplsLabel(MplsLabel) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a MPLS label modification.
mods() - Method in class org.onosproject.ui.topo.LinkHighlight
Returns the highlight modifications.
modTcpDst(TpPort) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a TCP dst modification.
modTcpSrc(TpPort) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a TCP src modification.
ModTransportPortInstruction(L4ModificationInstruction.L4SubType, TpPort) - Constructor for class org.onosproject.net.flow.instructions.L4ModificationInstruction.ModTransportPortInstruction
 
modTunnelId(long) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a Tunnel ID modification.
modUdpDst(TpPort) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a UDP dst modification.
modUdpSrc(TpPort) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a UDP src modification.
ModulationConfig<T> - Interface in org.onosproject.net.behaviour
 
ModulationScheme - Enum in org.onosproject.net
 
modVlanId(VlanId) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a VLAN ID modification.
modVlanPcp(Byte) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a VLAN PCP modification.
monitorDstPorts() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
Returns dst ports to monitor.
monitorDstPorts() - Method in interface org.onosproject.net.behaviour.MirroringDescription
Returns dst ports to monitor.
monitorSrcPorts() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
Returns src ports to monitor.
monitorSrcPorts() - Method in interface org.onosproject.net.behaviour.MirroringDescription
Returns src ports to monitor.
monitorVlans() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
Returns vlans to monitor.
monitorVlans() - Method in interface org.onosproject.net.behaviour.MirroringDescription
Returns vlans to monitor.
moreFragment - Variable in class org.onlab.packet.ipv6.Fragment
 
moveLeadership(String, NodeId) - Method in interface org.onosproject.cluster.LeadershipStore
Updates state so that given node is leader for a topic.
MPLS - Class in org.onlab.packet
Representation of an MPLS Packet.
MPLS - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a MPLS tunnel.
MPLS - org.onosproject.net.EncapsulationType
Indicates an MPLS encapsulation.
MPLS() - Constructor for class org.onlab.packet.MPLS
Default constructor that sets the version to 4.
MPLS_BOS - org.onosproject.net.flow.criteria.Criterion.Type
MPLS BoS bit.
MPLS_BOS - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
MPLS BOS instruction.
MPLS_LABEL - org.onosproject.net.flow.criteria.Criterion.Type
MPLS label.
MPLS_LABEL - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
MPLS Label modification.
MPLS_MULTICAST - org.onlab.packet.EthType.EtherType
 
MPLS_MULTICAST - Static variable in class org.onlab.packet.Ethernet
 
MPLS_POP - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
MPLS Pop modification.
MPLS_PUSH - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
MPLS Push modification.
MPLS_TC - org.onosproject.net.flow.criteria.Criterion.Type
MPLS TC.
MPLS_UNICAST - org.onlab.packet.EthType.EtherType
 
MPLS_UNICAST - Static variable in class org.onlab.packet.Ethernet
 
mplsBos() - Method in class org.onosproject.net.flow.criteria.MplsBosCriterion
 
mplsBos() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsBosInstruction
 
MplsBosCriterion - Class in org.onosproject.net.flow.criteria
Implementation of MPLS BOS criterion (1 bit).
MplsCriterion - Class in org.onosproject.net.flow.criteria
Implementation of MPLS tag criterion (20 bits).
mplsLabel(int) - Static method in class org.onlab.packet.MplsLabel
 
mplsLabel(String) - Static method in class org.onlab.packet.MplsLabel
Creates a MplsLabel object using the supplied decimal string.
MplsLabel - Class in org.onlab.packet
Representation of a MPLS label.
MplsLabel(int) - Constructor for class org.onlab.packet.MplsLabel
 
MplsQuery - Interface in org.onosproject.net.behaviour
A HandlerBehaviour to check the capability of MPLS.
MplsTcCriterion - Class in org.onosproject.net.flow.criteria
Implementation of MPLS TC criterion (3 bits).
msbIndex() - Method in class org.onlab.util.ImmutableByteSequence
Returns the index of the most significant bit (MSB), assuming a bit numbering scheme of type "LSB 0", i.e.
MULTI_LIST - org.onosproject.net.meter.MeterFeaturesFlag
Support multiple actions in action list.
multicast(M, MessageSubject, Function<M, byte[]>, Set<NodeId>) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
Multicasts a message to a set of controller nodes.
MULTICAST_GROUP - org.onosproject.net.pi.runtime.PiPreEntryType
Multicast group entry.
MulticastRouteService - Interface in org.onosproject.net.mcast
Deprecated.
in 1.11 ("Loon") release. To be moved into an app.
MultimapEvent<K,​V> - Class in org.onosproject.store.service
Representation of a ConsistentMultimap update notification.
MultimapEvent(String, K, V, V) - Constructor for class org.onosproject.store.service.MultimapEvent
Creates a new event object.
MultimapEvent.Type - Enum in org.onosproject.store.service
MultimapEvent type.
MultimapEventListener<K,​V> - Interface in org.onosproject.store.service
Listener to be notified about updates to a ConsistentMultimap.
multiplier() - Method in enum org.onlab.util.DataRateUnit
Returns the multiplier to use, when converting value of this unit to bps.
multiply(long) - Method in class org.onlab.util.Frequency
Returns a Frequency whose value is (this * value).
MultiPointToSinglePointIntent - Class in org.onosproject.net.intent
Abstraction of multiple source to single destination connectivity intent.
MultiPointToSinglePointIntent() - Constructor for class org.onosproject.net.intent.MultiPointToSinglePointIntent
Constructor for serializer.
MultiPointToSinglePointIntent.Builder - Class in org.onosproject.net.intent
Builder of a multi point to single point intent.
MultiValuedTimestamp<T extends Comparable<T>,​U extends Comparable<U>> - Class in org.onosproject.store.service
A logical timestamp that derives its value from two input values.
MultiValuedTimestamp(T, U) - Constructor for class org.onosproject.store.service.MultiValuedTimestamp
Creates a new timestamp based on two values.
MutableAdjacencyListsGraph<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
 
MutableAdjacencyListsGraph(Set<V>, Set<E>) - Constructor for class org.onlab.graph.MutableAdjacencyListsGraph
Creates a graph comprising of the specified vertexes and edges.
MutableAnnotations - Interface in org.onosproject.net
Represents an mutable set of simple key/value string annotations.
MutableGraph<V extends Vertex,​E extends Edge> - Interface in org.onlab.graph
Abstraction of a mutable graph that can be constructed gradually.
MutablePath<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Abstraction of a mutable path that allows gradual construction.
MUTEX_WRITE - org.onosproject.security.AppPermission.Type
 
MutexTask - Interface in org.onosproject.store.service
The MutexTask interface should be implemented by any class whose instances distributed across controllers are intended to be executed in a mutually exclusive fashion.

N

N_GIGA - Static variable in class org.onosproject.ui.topo.TopoUtils
 
N_KILO - Static variable in class org.onosproject.ui.topo.TopoUtils
 
N_MEGA - Static variable in class org.onosproject.ui.topo.TopoUtils
 
name - Variable in class org.onosproject.security.Permission
 
name() - Method in interface org.onosproject.app.ApplicationDescription
Returns the application name id.
name() - Method in class org.onosproject.app.DefaultApplicationDescription
 
name() - Method in class org.onosproject.cfg.ComponentConfigEvent
Returns the property name.
name() - Method in class org.onosproject.cfg.ConfigProperty
Returns the property name.
name() - Method in interface org.onosproject.core.ApplicationId
Returns the applications supplied identifier.
name() - Method in class org.onosproject.core.DefaultApplicationId
 
name() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the name of this bandwidth profile.
name() - Method in interface org.onosproject.net.behaviour.BridgeDescription
Returns bridge name.
name() - Method in class org.onosproject.net.behaviour.BridgeName
Returns the bridge name string.
name() - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription
 
name() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
Returns mirroring name.
name() - Method in interface org.onosproject.net.behaviour.MirroringDescription
Returns mirroring name.
name() - Method in class org.onosproject.net.behaviour.MirroringName
Returns the mirroring name string.
name() - Method in class org.onosproject.net.behaviour.MirroringStatistics
Returns the mirroring name string.
name() - Method in class org.onosproject.net.behaviour.QosId
 
name() - Method in class org.onosproject.net.behaviour.QueueId
 
name() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns friendly label for the element.
name() - Method in class org.onosproject.net.config.basics.BasicHostConfig
 
name() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
Returns the name of the interface.
name() - Method in interface org.onosproject.net.device.DeviceInterfaceDescription
Returns the name of the interface.
name() - Method in class org.onosproject.net.driver.DefaultDriver
 
name() - Method in interface org.onosproject.net.driver.Driver
Returns the driver name.
name() - Method in class org.onosproject.net.intf.Interface
Retrieves the name of the interface.
name() - Method in class org.onosproject.net.key.CommunityName
Returns the community name.
name() - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
name() - Method in interface org.onosproject.net.packet.PacketInFilter
Get the name of the counter.
name() - Method in class org.onosproject.net.PortNumber
Returns the backing string value.
name() - Method in class org.onosproject.net.region.DefaultRegion
 
name() - Method in interface org.onosproject.net.region.Region
Returns the friendly region name that can be used for display purposes.
name() - Method in class org.onosproject.rest.ApiDocProvider
Returns the REST API name.
name() - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
 
name() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns the name of the primitive.
name() - Method in class org.onosproject.store.service.AtomicValueEvent
Returns the AtomicValue name.
name() - Method in interface org.onosproject.store.service.DistributedPrimitive
Returns the name of this primitive.
name() - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
Returns the map name.
name() - Method in class org.onosproject.store.service.MapEvent
Returns the map name.
name() - Method in class org.onosproject.store.service.MapInfo
Returns the name of the map.
name() - Method in class org.onosproject.store.service.MultimapEvent
Returns the map name.
name() - Method in class org.onosproject.store.service.SetEvent
Returns the set name.
name() - Method in class org.onosproject.store.service.Synchronous
 
name() - Method in class org.onosproject.ui.model.topo.UiElement
Returns a friendly name to be used for display purposes.
name() - Method in class org.onosproject.ui.model.topo.UiRegion
 
name() - Method in interface org.onosproject.ui.UiTopoHighlighter
Returns the self-assigned name of the hilighter.
name(String) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the name of this bandwidth profile builder.
name(String) - Method in interface org.onosproject.net.behaviour.BridgeDescription.Builder
Returns bridge description builder with a given name.
name(String) - Method in class org.onosproject.net.behaviour.DefaultBridgeDescription.Builder
 
name(String) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets friendly label for the element.
NAME - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for instance name.
NAME - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for friendly name.
NAME - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
NAME - Static variable in class org.onosproject.routing.config.BgpConfig
 
NAME_SUBTYPE - Static variable in class org.onlab.packet.ONOSLLDP
 
namedThreads(String) - Static method in class org.onlab.util.Tools
Returns a thread factory that produces threads named according to the supplied name pattern.
NAPacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
NAPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.NAPacketClassifier
 
NATURAL - org.onosproject.store.service.Ordering
Indicates that items should be ordered in their natural order.
navigableKeySet() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
navigableKeySet() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Returns a navigable set of the keys in this map.
navigableKeySet() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns a navigable set of the keys in this map.
navPath() - Method in class org.onosproject.ui.topo.PropertyPanel
Returns the navigation path.
navPath(String) - Method in class org.onosproject.ui.topo.PropertyPanel
Adds a navigation path field to the panel data, to be included in the returned JSON data to the client.
NDP - org.onosproject.net.neighbour.NeighbourProtocol
Neighbor Discovery Protocol (IPv6).
NDP_HOP_LIMIT - Static variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
NDP_HOP_LIMIT - Static variable in class org.onlab.packet.ndp.NeighborSolicitation
 
NDP_OVERRIDE_FLAG - Static variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
NDP_SOLICITED_FLAG - Static variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
NEIGHBOR_ADVERTISEMENT - org.onosproject.cli.net.Icmp6Type
Neighbor Advertisement.
NEIGHBOR_ADVERTISEMENT - Static variable in class org.onlab.packet.ICMP6
Neighbor Advertisement.
NEIGHBOR_SOLICITATION - org.onosproject.cli.net.Icmp6Type
Neighbor Solicitation.
NEIGHBOR_SOLICITATION - Static variable in class org.onlab.packet.ICMP6
Neighbor Solicitation.
NeighborAdvertisement - Class in org.onlab.packet.ndp
Implements ICMPv6 Neighbor Advertisement packet format (RFC 4861).
NeighborAdvertisement() - Constructor for class org.onlab.packet.ndp.NeighborAdvertisement
 
NeighborDiscoveryOptions - Class in org.onlab.packet.ndp
Neighbor Discovery Protocol packet options.
NeighborDiscoveryOptions() - Constructor for class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
NeighborDiscoveryOptions.Option - Class in org.onlab.packet.ndp
Packet option.
NeighborSolicitation - Class in org.onlab.packet.ndp
Implements ICMPv6 Neighbor Solicitation packet format.
NeighborSolicitation() - Constructor for class org.onlab.packet.ndp.NeighborSolicitation
 
NeighbourHandlerRegistration - Interface in org.onosproject.net.neighbour
Information about the registration of a neighbour message handler.
NeighbourHandlersListCommand - Class in org.onosproject.cli.net
Lists neighbour message handlers.
NeighbourHandlersListCommand() - Constructor for class org.onosproject.cli.net.NeighbourHandlersListCommand
 
NeighbourMessageActions - Interface in org.onosproject.net.neighbour
Performs actions on a neighbour message contexts.
NeighbourMessageContext - Interface in org.onosproject.net.neighbour
Context of an incoming neighbor message (e.g.
NeighbourMessageHandler - Interface in org.onosproject.net.neighbour
Handler for an incoming neighbour message.
NeighbourMessageType - Enum in org.onosproject.net.neighbour
Neighbour message type.
NeighbourProtocol - Enum in org.onosproject.net.neighbour
Enumerates protocols used for neighbour discover/address resolution.
NeighbourResolutionService - Interface in org.onosproject.net.neighbour
Provides a means of registering logic for handling neighbour messages.
NetconfOperationCompleter - Class in org.onosproject.cli.net
Netconf Operation Completer.
NetconfOperationCompleter() - Constructor for class org.onosproject.cli.net.NetconfOperationCompleter
 
NETWORK - org.onosproject.cpman.ControlResource.Type
 
NETWORK - org.onosproject.ui.UiView.Category
Represents network-control related views.
NETWORK_CONTROL - org.onlab.packet.IPPrecedence
 
NETWORK_METRICS - Static variable in class org.onosproject.cpman.ControlResource
 
NetworkConfigCommand - Class in org.onosproject.cli.cfg
Manages network configuration.
NetworkConfigCommand() - Constructor for class org.onosproject.cli.cfg.NetworkConfigCommand
 
NetworkConfigEvent - Class in org.onosproject.net.config
Describes network configuration event.
NetworkConfigEvent(NetworkConfigEvent.Type, Object, Class) - Constructor for class org.onosproject.net.config.NetworkConfigEvent
Creates an event of a given type and for the specified subject and the current time.
NetworkConfigEvent(NetworkConfigEvent.Type, Object, Class, long) - Constructor for class org.onosproject.net.config.NetworkConfigEvent
Creates an event of a given type and for the specified subject and time.
NetworkConfigEvent(NetworkConfigEvent.Type, Object, Config, Config, Class) - Constructor for class org.onosproject.net.config.NetworkConfigEvent
Creates an event of a given type and for the specified subject, previous config and time.
NetworkConfigEvent.Type - Enum in org.onosproject.net.config
Type of network configuration events.
NetworkConfigListener - Interface in org.onosproject.net.config
Entity capable of receiving network configuration related events.
NetworkConfigRegistry - Interface in org.onosproject.net.config
Service for tracking network configuration factories.
NetworkConfigRegistryAdapter - Class in org.onosproject.net.config
Test adapter for network configuration service registry.
NetworkConfigRegistryAdapter() - Constructor for class org.onosproject.net.config.NetworkConfigRegistryAdapter
 
NetworkConfigRegistryCommand - Class in org.onosproject.cli.cfg
Displays network configuration registry contents.
NetworkConfigRegistryCommand() - Constructor for class org.onosproject.cli.cfg.NetworkConfigRegistryCommand
 
NetworkConfigService - Interface in org.onosproject.net.config
Service for tracking network configurations which specify how the discovered network information should be interpreted and how the core or applications should act on or configure the network.
NetworkConfigServiceAdapter - Class in org.onosproject.net.config
Test adapter for network configuration service.
NetworkConfigServiceAdapter() - Constructor for class org.onosproject.net.config.NetworkConfigServiceAdapter
 
NetworkConfigStore - Interface in org.onosproject.net.config
Mechanism for distributing and storing network configuration information.
NetworkConfigStoreDelegate - Interface in org.onosproject.net.config
Network configuration store delegate abstraction.
NetworkResource - Interface in org.onosproject.net
Representation of a network resource, e.g.
newActiveMemberForPartition(PartitionId, NodeId) - Method in interface org.onosproject.cluster.ClusterMetadataProviderService
Notifies that a node just become the active member of a partition.
newArray(ObjectNode, String) - Method in class org.onosproject.rest.AbstractWebResource
Creates and returns a new child array within the specified parent and bound to the given key.
newAsyncAtomicCounterMap(AtomicCounterMapOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncAtomicCounterMap.
newAsyncAtomicValue(AtomicValueOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncAtomicValue.
newAsyncConsistentMap(ConsistentMapOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncConsistentMap.
newAsyncConsistentSetMultimap(ConsistentMultimapOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new set backed AsyncConsistentMultimap.
newAsyncConsistentTreeMap(ConsistentTreeMapOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncConsistentTreeMap.
newAsyncCounter(AtomicCounterOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncAtomicCounter.
newAsyncDistributedLock(DistributedLockOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncDistributedLock.
newAsyncDistributedSet(DistributedSetOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncDistributedSet.
newAsyncDocumentTree(DocumentTreeOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncDocumentTree.
newAsyncIdGenerator(AtomicIdGeneratorOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncAtomixIdGenerator.
newAsyncLeaderElector(LeaderElectorOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new AsyncLeaderElector.
newBuilder() - Static method in class org.onlab.util.KryoNamespace
Creates a new KryoNamespace builder.
newBuilder() - Static method in class org.onosproject.store.primitives.MapUpdate
Creates a new builder instance.
newBuilder() - Static method in class org.onosproject.store.primitives.NodeUpdate
Creates a new builder instance.
newDeviceAdded(DeviceId) - Method in class org.onosproject.ui.model.topo.UiRegion
 
newDwdmSlot(ChannelSpacing, int) - Static method in class org.onosproject.net.OchSignal
Creates an instance of OchSignal representing a fixed DWDM frequency slot.
newFixedThreadPool(int, ThreadFactory) - Static method in class org.onlab.util.BoundedThreadPool
Returns a fixed-size, bounded executor service.
newFlexGridSlot(int) - Static method in class org.onosproject.net.OchSignal
Creates an instance of OchSignal representing a flex grid frequency slot.
newHandlers() - Method in interface org.onosproject.ui.UiMessageHandlerFactory
Produces a collection of new message handlers.
newObject(ObjectNode, String) - Method in class org.onosproject.rest.AbstractWebResource
Creates and returns a new child object within the specified parent and bound to the given key.
newOchSignalTreeSet() - Static method in class org.onosproject.net.DefaultOchSignalComparator
Creates a new instance of TreeSet using this Comparator.
newOverlays() - Method in interface org.onosproject.ui.UiTopo2OverlayFactory
Produces a collection of new overlay handlers for topology-2 view.
newOverlays() - Method in interface org.onosproject.ui.UiTopoOverlayFactory
Produces a collection of new overlay handlers.
newPredictableExecutor(int, ThreadFactory) - Static method in class org.onlab.util.PredictableExecutor
Creates PredictableExecutor instance.
newSingleThreadExecutor(ThreadFactory) - Static method in class org.onlab.util.BoundedThreadPool
Returns a single-thread, bounded executor service.
newStage() - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
Closes the current stage and starts a new one.
newTaskFor(Runnable, T) - Method in class org.onlab.util.PredictableExecutor
 
newTaskFor(Callable<T>) - Method in class org.onlab.util.PredictableExecutor
 
newThread(Runnable) - Method in class org.onlab.util.GroupedThreadFactory
 
newTimeout(TimerTask, long, TimeUnit) - Static method in class org.onlab.util.Timer
Executes one-shot timer task on shared thread pool.
newTimeout(Runnable, long, TimeUnit) - Static method in class org.onlab.util.SharedScheduledExecutors
Executes one-shot timer task on shared thread pool.
newTopoHighlighter() - Method in interface org.onosproject.ui.UiTopoHighlighterFactory
Produces a new topology highlighter.
newTypedStoredFlowEntry(FlowEntry) - Static method in class org.onosproject.net.statistic.TypedFlowEntryWithLoad
Creates a new typed flow entry with the given flow entry fe.
newValue() - Method in class org.onosproject.cluster.PartitionDiff
Returns the new partition value.
newValue() - Method in class org.onosproject.event.Change
Returns new or current value.
newValue() - Method in class org.onosproject.store.service.AtomicValueEvent
Returns the newly set value.
newValue() - Method in class org.onosproject.store.service.DocumentTreeEvent
Returns the new value.
newValue() - Method in class org.onosproject.store.service.MapEvent
Returns the new value in the map associated with the key.
newValue() - Method in class org.onosproject.store.service.MultimapEvent
Returns the new value in the map associated with the key.
newWorkQueue(WorkQueueOptions) - Method in interface org.onosproject.store.primitives.DistributedPrimitiveCreator
Creates a new WorkQueue.
next() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
next() - Method in interface org.onosproject.net.flowobjective.NextObjective
Deprecated.
in 1.14.2, replaced by NextObjective.nextTreatments()
next() - Method in interface org.onosproject.store.service.AsyncIterator
Returns the next item in the iterator.
next(DeviceId, NextObjective) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Installs the next hop elements into the specified device.
next(NextObjective) - Method in interface org.onosproject.net.behaviour.Pipeliner
Installs the next hop elements into the device.
NEXT - Static variable in class org.onosproject.ui.GlyphConstants
 
NEXT_HEADER_ERR - org.onosproject.cli.net.Icmp6Code
Unrecognized Next Header type encountered.
NEXT_HEADER_ERR - Static variable in class org.onlab.packet.ICMP6
Unrecognized Next Header type encountered.
nextElement() - Method in class org.onosproject.rest.AbstractInjectionResource.StreamEnumeration
 
NextGroup - Interface in org.onosproject.net.behaviour
Opaque data type for carrying group-like information.
nextHeader - Variable in class org.onlab.packet.ipv6.Authentication
 
nextHeader - Variable in class org.onlab.packet.ipv6.BaseOptions
 
nextHeader - Variable in class org.onlab.packet.ipv6.Fragment
 
nextHeader - Variable in class org.onlab.packet.IPv6
 
nextHeader - Variable in class org.onlab.packet.ipv6.Routing
 
nextHop - Variable in class org.onlab.packet.RIPV2Entry
 
NextHop - Class in org.onosproject.routing
Represents a next hop for routing, whose MAC address has already been resolved.
NextHop(IpAddress, MacAddress, NextHopGroupKey) - Constructor for class org.onosproject.routing.NextHop
Creates a new next hop.
NEXTHOP_METRIC - Static variable in class org.onlab.packet.RIPngEntry
 
NEXTHOP_METRIC - Static variable in class org.onlab.packet.RIPV2Entry
 
NextHopGroupKey - Class in org.onosproject.routing
Identifier for a next hop group.
NextHopGroupKey(IpAddress) - Constructor for class org.onosproject.routing.NextHopGroupKey
Creates a new next hop group key.
nextId() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
nextId() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective
Obtain the traffic treatment for this objective.
nextId() - Method in class org.onosproject.net.flowobjective.IdNextTreatment
Returns next id.
nextId() - Method in class org.onosproject.store.primitives.DefaultAtomicIdGenerator
 
nextId() - Method in interface org.onosproject.store.service.AsyncAtomicIdGenerator
Returns the next globally unique numeric ID.
nextId() - Method in interface org.onosproject.store.service.AtomicIdGenerator
Gets the next globally unique numeric identifier.
nextId(int) - Method in class org.onlab.util.KryoNamespace.Builder
Sets the next Kryo registration Id for following register entries.
NextObjective - Interface in org.onosproject.net.flowobjective
Represents a nexthop which will be translated by a driver into the appropriate group or actions needed to implement the egress function.
NextObjective.Builder - Interface in org.onosproject.net.flowobjective
A next step builder.
NextObjective.Type - Enum in org.onosproject.net.flowobjective
Represents the type of next phase to build.
NextObjQueueKey - Class in org.onosproject.net.flowobjective
Next objective queue key.
NextObjQueueKey(DeviceId, int) - Constructor for class org.onosproject.net.flowobjective.NextObjQueueKey
 
nextState(IntentData, IntentState) - Static method in class org.onosproject.net.intent.IntentData
Create a copy of IntentData in next state.
nextStep(int) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
nextStep(int) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Assigns a next step to the forwarding objective.
NextTreatment - Interface in org.onosproject.net.flowobjective
Represents next action in the NextObjective.
NextTreatment.Type - Enum in org.onosproject.net.flowobjective
Types of next action.
nextTreatments() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
nextTreatments() - Method in interface org.onosproject.net.flowobjective.NextObjective
The collection of next treatments that need to be applied to a set of traffic.
NICIRA_CT - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_CT_CLEAR - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_ENCAP_ETH_DST - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_ENCAP_ETH_SRC - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_ENCAP_ETH_TYPE - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_LOAD - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MATCH_CONNTRACK_LABEL - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_CONNTRACK_MARK - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_CONNTRACK_STATE - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_CONNTRACK_ZONE - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_ENCAP_ETH_TYPE - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_NSH_CH1 - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_NSH_CH2 - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_NSH_CH3 - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_NSH_CH4 - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_NSH_SI - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MATCH_NSH_SPI - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
NICIRA_MOV_ARP_SHA_TO_THA - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_ARP_SPA_TO_TPA - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_ETH_SRC_TO_DST - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_IP_SRC_TO_DST - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_NSH_C1_TO_C1 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_NSH_C2_TO_C2 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_NSH_C2_TO_TUN_ID - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_NSH_C3_TO_C3 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_NSH_C4_TO_C4 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_TUN_ID_TO_TUN_ID - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_MOV_TUN_IPV4_DST_TO_TUN_IPV4_DST - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_NAT - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_NSH_MDTYPE - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_NSH_NP - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_POP_NSH - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_PUSH_NSH - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_RESUBMIT - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_RESUBMIT_TABLE - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_NSH_CH1 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_NSH_CH2 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_NSH_CH3 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_NSH_CH4 - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_NSH_SI - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_NSH_SPI - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_SET_TUNNEL_DST - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NICIRA_TUN_GPE_NP - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
NO_DISPLAY_NUMBER - Static variable in class org.onosproject.net.PortNumber
 
NO_DRIVER - Static variable in class org.onosproject.net.AbstractProjectableModel
 
NO_DRIVER_SERVICE - Static variable in class org.onosproject.net.AbstractProjectableModel
 
NO_FLOWS - org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Means packet stopped due to missing flows.
NO_GROUP_MEMBERS - org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Means packet stopped due to an empty group.
NO_GROUPS - org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Means packet stopped due to missing groups.
NO_HIGHLIGHT - org.onosproject.ui.topo.LinkHighlight.Flavor
 
NO_INTERFACE_NAME - Static variable in class org.onosproject.net.intf.Interface
 
NO_REASON - org.onosproject.net.flow.FlowRule.FlowRemoveReason
 
NO_ROUTE - org.onosproject.cli.net.Icmp6Code
No route to destination.
NO_ROUTE - Static variable in class org.onlab.packet.ICMP6
No route to destination.
NO_VID - Static variable in class org.onlab.packet.VlanId
 
NOACTION - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic requires no action.
node - Variable in class org.onosproject.net.config.Config
 
node() - Method in class org.onosproject.net.config.Config
Returns the JSON node that contains the configuration data.
node(ObjectNode, String) - Static method in class org.onosproject.ui.JsonUtils
Returns the specified node property as an object node.
Node - Interface in org.onosproject.cluster
Represents a controller instance as a member in a cluster.
NODE - Static variable in class org.onosproject.ui.GlyphConstants
 
NODE_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
NodeBadge - Class in org.onosproject.ui.topo
Designates a badge to be applied to a node in the topology view.
NodeBadge.Status - Enum in org.onosproject.ui.topo
Designates the badge status.
NodeHighlight - Class in org.onosproject.ui.topo
Parent class of DeviceHighlight and HostHighlight.
NodeHighlight(TopoElementType, String) - Constructor for class org.onosproject.ui.topo.NodeHighlight
Constructs a node highlight entity.
nodeId() - Method in class org.onosproject.cluster.Leader
Returns the identifier for of leader.
nodeId() - Method in class org.onosproject.cluster.Member
Returns the node identifier.
nodeId() - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
nodeId() - Method in interface org.onosproject.net.packet.PacketRequest
Obtains the node id.
nodeId(String) - Static method in class org.onosproject.cluster.NodeId
Creates a new cluster node identifier from the specified string.
NodeId - Class in org.onosproject.cluster
Controller cluster identity.
NodeId(String) - Constructor for class org.onosproject.cluster.NodeId
Creates a new cluster node identifier from the specified string.
NodeIdCompleter - Class in org.onosproject.cli
Node ID completer.
NodeIdCompleter() - Constructor for class org.onosproject.cli.NodeIdCompleter
 
nodeIdSerializer() - Static method in class org.onosproject.store.serializers.NodeIdSerializer
 
NodeIdSerializer - Class in org.onosproject.store.serializers
Kryo Serializer for NodeId.
NodeIdSerializer() - Constructor for class org.onosproject.store.serializers.NodeIdSerializer
Creates NodeId serializer instance.
nodesAdded() - Method in class org.onosproject.cluster.ClusterMetadataDiff
Deprecated.
Returns the set of nodes added with this metadata change.
NodeSelection - Class in org.onosproject.ui.topo
Encapsulates a selection of devices, hosts and links from the topology view.
NodeSelection(ObjectNode, DeviceService, HostService, LinkService) - Constructor for class org.onosproject.ui.topo.NodeSelection
Creates a node selection entity, from the given payload, using the supplied link, device and host services.
NodesListCommand - Class in org.onosproject.cli
Lists all controller cluster nodes.
NodesListCommand() - Constructor for class org.onosproject.cli.NodesListCommand
 
nodesRemoved() - Method in class org.onosproject.cluster.ClusterMetadataDiff
Deprecated.
Returns the set of nodes removed with this metadata change.
NodeUpdate<V> - Class in org.onosproject.store.primitives
DocumentTree node update operation.
NodeUpdate() - Constructor for class org.onosproject.store.primitives.NodeUpdate
 
NodeUpdate.Builder<V> - Class in org.onosproject.store.primitives
NodeUpdate builder.
NodeUpdate.Type - Enum in org.onosproject.store.primitives
Type of database update operation.
NOEXT - org.onosproject.cli.net.ExtHeader
No next header.
noFlows() - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
Sets no flows in the result.
noGroups() - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
Sets no groups in the result.
noMembers() - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
Sets no flows in the result.
noMessageNoCause() - Method in class org.onlab.junit.ExceptionTest
 
noMeterFeatures(DeviceId) - Static method in class org.onosproject.net.meter.DefaultMeterFeatures
 
NON_DISRUPTIVE_INSTALLATION_WAITING_TIME - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NON_DISRUPTIVE_INSTALLATION_WAITING_TIME_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NON_VIABLE_WEIGHT - Static variable in class org.onlab.graph.ScalarWeight
Instance of scalar weight to mark links/paths which can not be traversed.
nonDisruptive() - Static method in class org.onosproject.net.intent.constraint.NonDisruptiveConstraint
Returns the nonDisruptiveConstraint.
NonDisruptiveConstraint - Class in org.onosproject.net.intent.constraint
Constraint to request a non-disruptive intent reallocation.
NonDisruptiveConstraint() - Constructor for class org.onosproject.net.intent.constraint.NonDisruptiveConstraint
 
none() - Method in class org.onosproject.ui.topo.NodeSelection
Returns true if nothing is selected.
NONE - org.onosproject.net.EncapsulationType
Indicates no encapsulation.
NONE - org.onosproject.net.MastershipRole
Represents that the controller instance is not eligible to be the master to a device or a region of network environment.
NONE - org.onosproject.net.meter.Band.Type
Deprecated.
in onos-2.5, replace by MARK_YELLOW and MARK_RED
NONE - org.onosproject.store.service.RevisionType
A distributed primitive that is initialized with an empty state.
NONE - Static variable in class org.onlab.packet.MacAddress
Dummy MAC address.
NONE - Static variable in class org.onlab.packet.VlanId
 
NONE - Static variable in class org.onosproject.alarm.AlarmEntityId
 
NONE - Static variable in class org.onosproject.net.behaviour.trafficcontrol.PolicerId
Represents either no id, or an unspecified id.
NONE - Static variable in class org.onosproject.net.DeviceId
Represents either no device, or an unspecified device.
NONE - Static variable in class org.onosproject.net.HostId
Represents either no host, or an unspecified host; used for creating open ingress/egress edge links.
NONE - Static variable in class org.onosproject.net.HostLocation
Represents a no location or an unknown location.
NONE - Static variable in class org.onosproject.net.provider.ProviderId
Represents no provider ID.
NONE - Static variable in class org.onosproject.net.TenantId
Represents no tenant, or an unspecified tenant.
NONEXT - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
"No next header" encountered.
nonNullCompare(Object, Object) - Method in class org.onosproject.ui.table.cell.AbstractCellComparator
Compares its two arguments for order.
nonNullCompare(Object, Object) - Method in class org.onosproject.ui.table.cell.DefaultCellComparator
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.AbstractCellFormatter
Formats the specified value into a string appropriate for displaying in a table cell.
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.AppIdFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.ConnectPointFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.DefaultCellFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.EnumFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.HexFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.HexLongFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.HostLocationFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.NumberFormatter
 
nonNullFormat(Object) - Method in class org.onosproject.ui.table.cell.TimeFormatter
 
NOOP - org.onosproject.net.behaviour.QosDescription.Type
No operation.
NOPIPELINER - org.onosproject.net.flowobjective.ObjectiveError
The device has no pipeline driver to install objectives.
NoRemoteHandler() - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException.NoRemoteHandler
 
NORMAL - org.onosproject.net.device.DeviceInterfaceDescription.Mode
Normal mode of interface operation.
NORMAL - org.onosproject.net.PortNumber.Logical
 
NORMAL - Static variable in class org.onosproject.net.PortNumber
 
noRowsMessage(ObjectNode) - Method in class org.onosproject.ui.table.TableRequestHandler
Subclasses should return the message to display in the table when there are no rows to display.
NoSuchDocumentPathException - Exception in org.onosproject.store.service
An exception to be thrown when an invalid path is passed to the DocumentTree.
NoSuchDocumentPathException() - Constructor for exception org.onosproject.store.service.NoSuchDocumentPathException
 
NoSuchDocumentPathException(String) - Constructor for exception org.onosproject.store.service.NoSuchDocumentPathException
 
NoSuchDocumentPathException(String, Throwable) - Constructor for exception org.onosproject.store.service.NoSuchDocumentPathException
 
NoSuchDocumentPathException(Throwable) - Constructor for exception org.onosproject.store.service.NoSuchDocumentPathException
 
NOT_EXPECTED - Static variable in class org.onosproject.net.link.DefaultLinkDescription
 
NOT_MASTER - org.onosproject.net.device.DeviceAgentEvent.Type
Signifies that the agent tried to perform some operations on the device that requires master role.
NOT_NULL - Static variable in class org.onlab.util.Match
 
NotFoundMapper - Class in org.onlab.rest.exceptions
Mapper for api not found exceptions to the NOT_FOUND response code.
NotFoundMapper() - Constructor for class org.onlab.rest.exceptions.NotFoundMapper
 
nothing() - Method in interface org.onosproject.routing.RoutingService
Empty method to pacify checkstyle.
notifies() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Returns true if this FAR notifies the control plane on receiving a packet, and false otherwise.
notify(E) - Method in interface org.onosproject.store.StoreDelegate
Notifies the delegate via the specified event.
notifyDelegate(E) - Method in class org.onosproject.store.AbstractStore
Notifies the delegate with the specified event.
notifyDelegate(List<E>) - Method in class org.onosproject.store.AbstractStore
Notifies the delegate with the specified list of events.
notifyMetricsChange() - Method in interface org.onlab.metrics.MetricsReporter
Notifies the changes on metric registry.
notifyOfFailovers(Collection<Group>) - Method in interface org.onosproject.net.group.GroupProviderService
Notifies store of group failovers.
notifyOfFailovers(Collection<Group>) - Method in interface org.onosproject.net.group.GroupStore
Indicates failover within a failover group.
notifyReporters() - Method in class org.onlab.metrics.MetricsManager
Notifies the changes on metric registry to all registered reporters.
notifyReporters() - Method in interface org.onlab.metrics.MetricsService
Notifies the changes on metric registry to all registered reporters.
notWipeDeferred() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
notWipeDeferred() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
the instruction to clear not wipe the deferred instructions set.
now() - Static method in class org.onlab.junit.TestTools
Returns the current time in millis since epoch.
now() - Method in interface org.onosproject.core.HybridLogicalClockService
Returns the current time derived from the hybrid logical time.
NRM_ARP_ENABLED - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NRM_ARP_ENABLED_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NRM_NDP_ENABLED - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NRM_NDP_ENABLED_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NRM_REQUEST_INTERCEPTS_ENABLED - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NRM_REQUEST_INTERCEPTS_ENABLED_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
NS - org.onosproject.net.flow.criteria.Criterion.TcpFlags
ECN-nonce concealment protection.
nshContextHeader() - Method in class org.onosproject.net.NshContextHeader
Returns nsh context header value.
NshContextHeader - Class in org.onosproject.net
 
NshServiceIndex - Class in org.onosproject.net
 
NshServicePathId - Class in org.onosproject.net
 
NSPacketClassifier - Class in org.onosproject.net.packet.packetfilter
 
NSPacketClassifier() - Constructor for class org.onosproject.net.packet.packetfilter.NSPacketClassifier
 
NULL - Static variable in class org.onlab.util.Match
 
NULL_ID - Static variable in class org.onosproject.ui.model.topo.UiRegion
The identifier for the null-region.
NULL_NAME - Static variable in class org.onosproject.ui.model.topo.UiRegion
 
NULL_WEIGHT_VALUE - Static variable in class org.onlab.graph.DefaultEdgeWeigher
Weight value for null path (without links).
nullIsIllegal(T, String) - Static method in class org.onlab.util.Tools
Returns the specified item if that item is not null; otherwise throws bad argument exception.
nullIsNotFound(T, String) - Static method in class org.onlab.util.Tools
Returns the specified item if that item is not null; otherwise throws not found exception.
nullRegion() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns a reference to the null-region.
NullScheduledExecutor - Class in org.onlab.junit
A scheduled executor service that does not do any of the work scheduled to it.
NullScheduledExecutor() - Constructor for class org.onlab.junit.NullScheduledExecutor
 
nullValues() - Method in class org.onosproject.store.service.ConsistentMapOptions
Returns whether null values are supported by the map.
NUM_OF_CORES - org.onosproject.cpman.ControlMetricType
 
NUM_OF_CPUS - org.onosproject.cpman.ControlMetricType
 
number() - Method in class org.onosproject.net.DefaultPort
 
number() - Method in interface org.onosproject.net.Port
Returns the port number.
number() - Method in enum org.onosproject.net.PortNumber.Logical
 
number() - Method in class org.onosproject.net.utils.ForwardingPort
 
number(int) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns a numeric badge, with default status.
number(ObjectNode, String) - Static method in class org.onosproject.ui.JsonUtils
Returns the specified node property as a number.
number(ObjectNode, String) - Method in class org.onosproject.ui.RequestHandler
Returns the specified node property as a number.
number(NodeBadge.Status, int) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns a numeric badge, with the given status and optional message.
number(NodeBadge.Status, int, String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns a numeric badge, with the given status and optional message.
NumberFormatter - Class in org.onosproject.ui.table.cell
Formats number using the specified format string.
NumberFormatter() - Constructor for class org.onosproject.ui.table.cell.NumberFormatter
Creates a formatter using the default format (no decimal places).
NumberFormatter(String) - Constructor for class org.onosproject.ui.table.cell.NumberFormatter
Creates a formatter using a DecimalFormat configured with the given format string.
NumberFormatter(NumberFormat) - Constructor for class org.onosproject.ui.table.cell.NumberFormatter
Creates a formatter using the specified NumberFormat.
NumericPortNumberCompleter - Class in org.onosproject.cli.net.completer
PortNumber completer, which returns candidates in decimal form.
NumericPortNumberCompleter() - Constructor for class org.onosproject.cli.net.completer.NumericPortNumberCompleter
 
numOfCores(int) - Method in interface org.onosproject.cpman.SystemInfo.Builder
Sets number of CPU cores.
numOfCpus(int) - Method in interface org.onosproject.cpman.SystemInfo.Builder
Sets number of CPUs.
NW_INCOMING_BYTES - org.onosproject.cpman.ControlMetricType
 
NW_INCOMING_PACKETS - org.onosproject.cpman.ControlMetricType
 
NW_OUTGOING_BYTES - org.onosproject.cpman.ControlMetricType
 
NW_OUTGOING_PACKETS - org.onosproject.cpman.ControlMetricType
 

O

O_BAND_MAX - Static variable in class org.onlab.util.Spectrum
 
O_BAND_MIN - Static variable in class org.onlab.util.Spectrum
 
object - Variable in class org.onosproject.net.config.Config
 
object() - Method in class org.onlab.util.CountDownCompleter
Returns the object.
Objective - Interface in org.onosproject.net.flowobjective
Base representation of a flow-objective description.
Objective.Builder - Interface in org.onosproject.net.flowobjective
An objective builder.
Objective.Operation - Enum in org.onosproject.net.flowobjective
Type of operation.
ObjectiveContext - Interface in org.onosproject.net.flowobjective
The context of a objective that will become the subject of the notification.
ObjectiveError - Enum in org.onosproject.net.flowobjective
Represents the set of errors possible when processing an objective.
ObjectiveEvent - Class in org.onosproject.net.flowobjective
Describes a objective event.
ObjectiveEvent(ObjectiveEvent.Type, Integer) - Constructor for class org.onosproject.net.flowobjective.ObjectiveEvent
Creates an event of the given type for the specified objective id.
ObjectiveEvent(ObjectiveEvent.Type, Integer, long) - Constructor for class org.onosproject.net.flowobjective.ObjectiveEvent
Creates an event of the given type for the specified objective id at the given time.
ObjectiveEvent.Type - Enum in org.onosproject.net.flowobjective
Type of objective events.
ObjectiveQueueKey - Interface in org.onosproject.net.flowobjective
Objective queue key.
objectives() - Method in class org.onosproject.net.intent.FlowObjectiveIntent
Returns the collection of backing flow objectives.
ObjectiveTrackerService - Interface in org.onosproject.net.intent
Auxiliary service for tracking intent path flows and for notifying the intent service of environment changes via topology change delegate.
objectNode() - Method in class org.onosproject.ui.UiMessageHandler
Returns a freshly minted object node.
OBLIQUE - Static variable in class org.onosproject.ui.GlyphConstants
 
observer(int) - Static method in interface org.onosproject.net.packet.PacketProcessor
Returns a priority in the OBSERVER range, where processors cannot take any action, but can observe what action has been taken until then.
OBSERVER_MAX - Static variable in interface org.onosproject.net.packet.PacketProcessor
 
ObstacleConstraint - Class in org.onosproject.net.intent.constraint
Constraint that evaluates elements not passed through.
ObstacleConstraint(DeviceId...) - Constructor for class org.onosproject.net.intent.constraint.ObstacleConstraint
Creates a new constraint that the specified device are not passed through.
obstacles() - Method in class org.onosproject.net.intent.constraint.ObstacleConstraint
Returns the obstacle device ids.
OCH - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a L0 OCH tunnel.
OCH - org.onosproject.net.flow.instructions.L0ModificationInstruction.L0SubType
OCh (Optical Channel) modification.
OCH - org.onosproject.net.Port.Type
Signifies optical fiber-based Line-side port (called L-port).
OCH_SIGID - org.onosproject.net.flow.criteria.Criterion.Type
Optical channel signal ID (lambda).
OCH_SIGTYPE - org.onosproject.net.flow.criteria.Criterion.Type
Optical channel signal type (fixed or flexible).
ochSignal() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
Returns the OCh signal of the intent.
ochSignal() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
Returns the OCh signal of the intent.
ochSignal(Optional<OchSignal>) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
Sets the OCh signal of the intent.
ochSignal(Optional<OchSignal>) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
Sets the OCh signal of the intent.
ochSignal(GridType, ChannelSpacing, int, int) - Static method in interface org.onosproject.net.Lambda
Creates a Lambda instance with the specified arguments.
OchSignal - Class in org.onosproject.net
Implementation of Lambda representing OCh (Optical Channel) Signal.
OchSignal(GridType, ChannelSpacing, int, int) - Constructor for class org.onosproject.net.OchSignal
Creates an instance with the specified arguments.
OchSignalCriterion - Class in org.onosproject.net.flow.criteria
Implementation of OCh (Optical Channel) signal criterion.
OchSignalType - Enum in org.onosproject.net
Represents OCh (Optical Channel) signal type defined in Open Networking Foundation "Optical Transport Protocol Extensions Version 1.0".
OchSignalTypeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of OCh (Optical Channel) signal type criterion.
ODU_SIGID - org.onosproject.net.flow.criteria.Criterion.Type
ODU (Optical channel Data Unit) signal ID.
ODU_SIGID - org.onosproject.net.flow.instructions.L1ModificationInstruction.L1SubType
ODU (Optical channel Data Unit) Signal Id modification.
ODU_SIGTYPE - org.onosproject.net.flow.criteria.Criterion.Type
ODU (Optical channel Data Unit) signal type.
ODU0 - org.onosproject.net.OduSignalType
 
ODU1 - org.onosproject.net.OduSignalType
 
ODU2 - org.onosproject.net.OduSignalType
 
ODU2e - org.onosproject.net.OduSignalType
 
ODU3 - org.onosproject.net.OduSignalType
 
ODU4 - org.onosproject.net.OduSignalType
 
ODUC1 - org.onosproject.net.OduSignalType
 
ODUC2 - org.onosproject.net.OduSignalType
 
ODUC3 - org.onosproject.net.OduSignalType
 
ODUC4 - org.onosproject.net.OduSignalType
 
ODUC5 - org.onosproject.net.OduSignalType
 
ODUC6 - org.onosproject.net.OduSignalType
 
ODUC7 - org.onosproject.net.OduSignalType
 
ODUC8 - org.onosproject.net.OduSignalType
 
ODUC9 - org.onosproject.net.OduSignalType
 
ODUCLT - org.onosproject.net.Port.Type
Signifies optical fiber-based optical tributary port (called T-port).
ODUK - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a L1 OTN tunnel.
oduSignalId() - Method in class org.onosproject.net.flow.criteria.OduSignalIdCriterion
Returns the ODU Signal to match.
oduSignalId() - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction.ModOduSignalIdInstruction
 
oduSignalId(int, int, byte[]) - Static method in class org.onosproject.net.OduSignalId
Returns the OduSignalId representing the specified parameters.
OduSignalId - Class in org.onosproject.net
Implementation of ODU Signal ID.
OduSignalId(int, int, byte[]) - Constructor for class org.onosproject.net.OduSignalId
Creates an instance with the specified arguments.
OduSignalIdCriterion - Class in org.onosproject.net.flow.criteria
Implementation of ODU (Optical channel Data Unit) signal ID signal criterion.
OduSignalType - Enum in org.onosproject.net
Represents ODU (Optical channel Data Unit) signal type.
OduSignalTypeCriterion - Class in org.onosproject.net.flow.criteria
Implementation of ODU (Optical channel Data Unit) signal Type criterion.
OduSignalUtils - Class in org.onosproject.net
Collection of helper methods to convert various SignalTypes to OduSignalType, and to build OduSignalId.
of(byte[]) - Static method in class org.onlab.util.ByteArraySizeHashPrinter
Returns ByteArraySizeHashPrinter wrapping given byte[].
of(double, DataRateUnit) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth.
of(double, DataRateUnit) - Static method in class org.onosproject.net.intent.constraint.BandwidthConstraint
Creates a new bandwidth constraint.
of(int) - Static method in class org.onosproject.net.flow.IndexTableId
Returns a table identifier for the given index.
of(int) - Static method in class org.onosproject.net.flowobjective.IdNextTreatment
Returns an instance of IdNextTreatment with given next id.
of(int) - Static method in class org.onosproject.net.NshContextHeader
Returns the NshContextHeader by setting its value.
of(int) - Static method in class org.onosproject.net.NshServicePathId
Returns the NshServicePathId by setting its value.
of(int) - Static method in class org.onosproject.net.pi.runtime.PiActionProfileGroupId
Returns an action profile group identifier for the given integer value.
of(int) - Static method in class org.onosproject.net.pi.runtime.PiActionProfileMemberId
Returns a member identifier for the given integer value.
of(int, int) - Static method in class org.onlab.util.ClosedOpenRange
Create a range with a lower bound and an upper bound.
of(int, int) - Static method in class org.onosproject.net.flowobjective.IdNextTreatment
Returns an instance of IdNextTreatment with given next id and weight.
of(long) - Static method in class org.onosproject.net.ResourceGroup
Creates a resource group identifier from the specified long representation.
of(long) - Static method in class org.onosproject.net.TributarySlot
 
of(long, Class<T>) - Static method in class org.onosproject.net.resource.ResourceConsumerId
Creates ResourceConsumerId from given value and class.
of(long, DataRateUnit) - Static method in interface org.onlab.util.Bandwidth
Creates a new instance with given bandwidth.
of(long, ApplicationId) - Static method in class org.onosproject.net.intent.Key
Creates a key based on the provided long.
of(short) - Static method in enum org.onlab.packet.dhcp.Dhcp6Duid.DuidType
 
of(short) - Static method in class org.onosproject.net.NshServiceIndex
Returns the NshServiceIndex by setting its value.
of(Range<Integer>) - Static method in class org.onlab.util.ClosedOpenRange
Creates a range from a Guava's range.
of(Boolean) - Static method in class org.onosproject.net.pi.runtime.data.PiBool
Returns a new protocol-independent Bool.
of(Boolean, List<ImmutableByteSequence>) - Static method in class org.onosproject.net.pi.runtime.data.PiHeader
Returns a new protocol-independent header.
of(String) - Static method in class org.onosproject.net.behaviour.protection.TransportEndpointId
Creates a TransportEndpointId from given String.
of(String) - Static method in class org.onosproject.net.meter.MeterScope
Create a Meter Scope from id string.
of(String) - Static method in class org.onosproject.net.pi.model.PiActionId
Returns an action identifier for the given action name.
of(String) - Static method in class org.onosproject.net.pi.model.PiActionParamId
Returns a parameter identifier for the given parameter name.
of(String) - Static method in class org.onosproject.net.pi.model.PiActionProfileId
Returns an identifier for the given action profile name.
of(String) - Static method in class org.onosproject.net.pi.model.PiCounterId
Returns an identifier for the given counter name.
of(String) - Static method in class org.onosproject.net.pi.model.PiMatchFieldId
Returns an identifier for the given match field name.
of(String) - Static method in class org.onosproject.net.pi.model.PiMeterId
Returns an identifier for the given meter name.
of(String) - Static method in class org.onosproject.net.pi.model.PiPacketMetadataId
Returns an identifier for the given packet metadata name.
of(String) - Static method in class org.onosproject.net.pi.model.PiRegisterId
Returns an identifier for the given register name.
of(String) - Static method in class org.onosproject.net.pi.model.PiTableId
Returns an identifier for the given table name.
of(String) - Static method in class org.onosproject.net.pi.runtime.data.PiEnumString
Returns a new protocol-independent enum string.
of(String) - Static method in class org.onosproject.net.pi.runtime.data.PiErrorString
Returns a new protocol-independent error string.
of(String) - Static method in class org.onosproject.net.ResourceGroup
Creates a resource group identifier from the specified string representation.
of(String, ApplicationId) - Static method in class org.onosproject.net.intent.Key
Creates a key based on the provided string.
of(String, PiHeader) - Static method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
Returns a new valid protocol-independent header union.
of(List<TransportEndpointDescription>, DeviceId, String) - Static method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
of(List<PiData>) - Static method in class org.onosproject.net.pi.runtime.data.PiStruct
Returns a new protocol-independent struct.
of(List<PiData>) - Static method in class org.onosproject.net.pi.runtime.data.PiTuple
Returns a new protocol-independent tuple.
of(List<PiHeader>) - Static method in class org.onosproject.net.pi.runtime.data.PiHeaderStack
Returns a new protocol-independent header stack.
of(List<PiHeaderUnion>) - Static method in class org.onosproject.net.pi.runtime.data.PiHeaderUnionStack
Returns a new protocol-independent header union stack.
of(ImmutableByteSequence) - Static method in class org.onosproject.net.pi.runtime.data.PiBitString
Returns a new protocol-independent BitString.
of(NodeId, long) - Static method in class org.onosproject.mastership.MastershipTerm
 
of(DeviceId, int) - Static method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
Creates a new handle for the given device ID and PI clone session ID.
of(DeviceId, int) - Static method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
Creates a new handle for the given device ID and PI multicast group ID.
of(DeviceId, PiActionProfileId, PiActionProfileMemberId) - Static method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
Creates a new handle for the given device ID, action profile ID, and member ID.
of(DeviceId, PiActionProfileGroup) - Static method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
Creates a new handle for the given device ID and PI action profile group.
of(DeviceId, PiActionProfileMember) - Static method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
Creates a new handle for the given device ID, and action profile group member instance.
of(DeviceId, PiCloneSessionEntry) - Static method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
Creates a new handle for the given device ID and PI clone session entry.
of(DeviceId, PiCounterCell) - Static method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
Creates a new handle for the given device ID and counter cell.
of(DeviceId, PiCounterCellId) - Static method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
Creates a new handle for the given device ID and counter cell ID.
of(DeviceId, PiMeterCellConfig) - Static method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
Creates a new handle for the given device ID and PI meter cell configuration.
of(DeviceId, PiMeterCellId) - Static method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
Creates a new handle for the given device ID and PI meter cell ID.
of(DeviceId, PiMulticastGroupEntry) - Static method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
Creates a new handle for the given device ID and PI multicast group entry.
of(DeviceId, PiTableEntry) - Static method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
Creates a new handle for the given PI table entry and device ID.
of(TrafficTreatment) - Static method in class org.onosproject.net.flowobjective.DefaultNextTreatment
Returns an instance of DefaultNextTreatment with given traffic treatment.
of(TrafficTreatment, int) - Static method in class org.onosproject.net.flowobjective.DefaultNextTreatment
Returns an instance of DefaultNextTreatment with given traffic treatment and weight.
of(PiRegisterId, long) - Static method in class org.onosproject.net.pi.runtime.PiRegisterCellId
Return a register cell ID for the given register ID and index.
of(RouterInfo, Interface) - Static method in class org.onosproject.routing.InterfaceProvisionRequest
Creates a new provision request from a router configuration and an interface.
of(T) - Static method in class org.onosproject.net.resource.ResourceConsumerId
Creates ResourceConsumerId instance from Identifier object.
OF_1_0 - org.onosproject.net.behaviour.ControlProtocolVersion
 
OF_1_1 - org.onosproject.net.behaviour.ControlProtocolVersion
 
OF_1_2 - org.onosproject.net.behaviour.ControlProtocolVersion
 
OF_1_3 - org.onosproject.net.behaviour.ControlProtocolVersion
 
OF_1_4 - org.onosproject.net.behaviour.ControlProtocolVersion
 
OF_1_5 - org.onosproject.net.behaviour.ControlProtocolVersion
 
ofDevice(DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Deprecated.
ofDirect(PiTableEntry) - Static method in class org.onosproject.net.pi.runtime.PiCounterCellId
Return a direct counter cell ID for the given counter ID and table entry.
ofDirect(PiTableEntry) - Static method in class org.onosproject.net.pi.runtime.PiMeterCellId
Return a direct meter cell ID for the given meter ID and table entry.
OFDPA_ALLOW_VLAN_TRANSLATION - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_MATCH_ACTSET_OUTPUT - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
OFDPA_MATCH_ALLOW_VLAN_TRANSLATION - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
OFDPA_MATCH_MPLS_L2_PORT - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
OFDPA_MATCH_OVID - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
OFDPA_MATCH_VLAN_VID - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
OFDPA_POP_CW - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_POP_L2_HEADER - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_PUSH_CW - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_PUSH_L2_HEADER - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_SET_MPLS_L2_PORT - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_SET_MPLS_TYPE - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_SET_OVID - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_SET_QOS_INDEX - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
OFDPA_SET_VLAN_ID - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
offer(E) - Method in class org.onlab.util.UnmodifiableDeque
 
offerFirst(E) - Method in class org.onlab.util.UnmodifiableDeque
 
offerLast(E) - Method in class org.onlab.util.UnmodifiableDeque
 
offset - Variable in class org.onlab.packet.RIPV2AuthEntry
 
offsetX() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the x-offset for the geomap / sprites background.
offsetX() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the x-offset value.
offsetX(double) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the x-offset value.
offsetX(Double) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the x-offset for the geomap / sprites background.
offsetY() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the y-offset for the geomap / sprites background.
offsetY() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the y-offset value.
offsetY(double) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the y-offset value.
offsetY(Double) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the scale for the geomap / sprites background.
ofGHz(double) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in GHz.
ofGHz(long) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in GHz.
ofHz(long) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in Hz.
ofIndirect(PiCounterId, long) - Static method in class org.onosproject.net.pi.runtime.PiCounterCellId
Return an indirect counter cell ID for the given counter ID and index.
ofIndirect(PiMeterId, long) - Static method in class org.onosproject.net.pi.runtime.PiMeterCellId
Return an indirect meter cell ID for the given meter ID and index.
ofInvalid() - Static method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
Returns a new invalid protocol-independent header union.
ofKHz(double) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in KHz.
ofKHz(long) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in KHz.
oFlag - Variable in class org.onlab.packet.ndp.RouterAdvertisement
 
ofMHz(double) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in MHz.
ofMHz(long) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in MHz.
ofOnes(int) - Static method in class org.onlab.util.ImmutableByteSequence
Creates a new byte sequence of the given size where all bits are 1.
ofTHz(double) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in THz.
ofTHz(long) - Static method in class org.onlab.util.Frequency
Returns an instance representing the specified value in THz.
ofType(Band.Type) - Method in interface org.onosproject.net.meter.Band.Builder
Assigns the Band.Type of this band.
ofType(Band.Type) - Method in class org.onosproject.net.meter.DefaultBand.Builder
 
ofZeros(int) - Static method in class org.onlab.util.ImmutableByteSequence
Creates a new byte sequence of the given size where all bits are 0.
ok(Object) - Static method in class org.onlab.rest.BaseResource
 
OLD_KEY_AN_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
OLD_KEY_RX_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
OLD_KEY_TX_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
oldValue() - Method in class org.onosproject.cluster.PartitionDiff
Returns the old partition value.
oldValue() - Method in class org.onosproject.event.Change
Returns previous value.
oldValue() - Method in class org.onosproject.store.service.AtomicValueEvent
Returns the old replaced value.
oldValue() - Method in class org.onosproject.store.service.DocumentTreeEvent
Returns the old value.
oldValue() - Method in class org.onosproject.store.service.MapEvent
Returns the value associated with the key, before it was updated.
oldValue() - Method in class org.onosproject.store.service.MultimapEvent
Returns the old value that was associated with the key.
OLS - org.onosproject.net.Device.Type
 
OLT - org.onosproject.net.Device.Type
 
OMS - org.onosproject.net.Port.Type
Signifies optical fiber-based WDM port (called W-port).
onApply(Config) - Method in interface org.onosproject.net.config.ConfigApplyDelegate
Processes changes applied to the specified configuration.
one() - Method in class org.onosproject.net.intent.HostToHostIntent
Returns identifier of the first host.
one() - Method in class org.onosproject.net.intent.ProtectedTransportIntent
Returns the transport endpoint device one.
one() - Method in class org.onosproject.net.intent.TwoWayP2PIntent
Returns identifier of the first host.
one() - Method in class org.onosproject.ui.topo.BiLink
Returns the first link in this bi-link.
one(ConnectPoint) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
Sets the first connection point of the two way intent that will be built.
one(DeviceId) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
Sets the transport endpoint device one.
one(HostId) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
Sets the first host of the intent that will be built.
ONE - org.onosproject.ui.topo.TopoUtils.Magnitude
 
onError(DomainIntentOperations) - Method in interface org.onosproject.net.domain.DomainIntentOperationsContext
Invoked when error is encountered while executing the domain intent.
onError(FlowRuleOperations) - Method in interface org.onosproject.net.flow.FlowRuleOperationsContext
 
onError(Objective, ObjectiveError) - Method in class org.onosproject.net.flowobjective.DefaultObjectiveContext
 
onError(Objective, ObjectiveError) - Method in interface org.onosproject.net.flowobjective.ObjectiveContext
Invoked when error is encountered while executing the flow objective.
onError(MeterRequest, MeterFailReason) - Method in interface org.onosproject.net.meter.MeterContext
Invoked when error is encountered while installing a meter.
oneShotOnly() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns true if the table supports one shot only when associated to an action profile.
ONF_COPY_FIELD - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
ONLY_FIRST - org.onosproject.net.flow.StatTriggerFlag
Trigger on only first reach threshold.
ONOS - org.onosproject.cluster.ClusterEvent.InstanceType
Signifies that the event refers to an ONOS instance.
ONOS - Static variable in class org.onlab.packet.MacAddress
First MAC address in ONOS OUI range.
ONOS_LLDP - Static variable in class org.onlab.packet.MacAddress
ONOS LLDP MAC address with slow protocol destination address.
onosLLDP(String, ChassisId, int) - Static method in class org.onlab.packet.ONOSLLDP
Deprecated.
since 1.15. Insecure, do not use.
onosLLDP(String, ChassisId, int, String) - Static method in class org.onlab.packet.ONOSLLDP
Deprecated.
since 1.15. Insecure, do not use.
ONOSLLDP - Class in org.onlab.packet
ONOS LLDP containing organizational TLV for ONOS device discovery.
ONOSLLDP(byte...) - Constructor for class org.onlab.packet.ONOSLLDP
 
onosSecureLLDP(String, ChassisId, int, String) - Static method in class org.onlab.packet.ONOSLLDP
Creates a link probe for link discovery/verification.
onosSecureLLDP(String, ChassisId, int, String, String) - Static method in class org.onlab.packet.ONOSLLDP
Creates a link probe for link discovery/verification.
onProcessLimit() - Method in interface org.onosproject.event.EventSink
Handles notification that event processing time limit has been exceeded.
onProcessLimit() - Method in class org.onosproject.event.ListenerRegistry
 
onSuccess(DomainIntentOperations) - Method in interface org.onosproject.net.domain.DomainIntentOperationsContext
Invoked on successful execution of the domain intent.
onSuccess(FlowRuleOperations) - Method in interface org.onosproject.net.flow.FlowRuleOperationsContext
 
onSuccess(Objective) - Method in class org.onosproject.net.flowobjective.DefaultObjectiveContext
 
onSuccess(Objective) - Method in interface org.onosproject.net.flowobjective.ObjectiveContext
Invoked on successful execution of the flow objective.
onSuccess(MeterRequest) - Method in interface org.onosproject.net.meter.MeterContext
Invoked on successful installation of the meter.
ONU - org.onosproject.net.Device.Type
 
onUpdate(IntentData) - Method in interface org.onosproject.net.intent.IntentStoreDelegate
Called when a new intent has been updated for which this node is the master.
op() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpOpInstruction
 
op() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
op() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
op() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
op() - Method in interface org.onosproject.net.flowobjective.Objective
The type of operation for this objective.
OP_RARP_REPLY - Static variable in class org.onlab.packet.ARP
 
OP_RARP_REQUEST - Static variable in class org.onlab.packet.ARP
 
OP_REPLY - Static variable in class org.onlab.packet.ARP
 
OP_REQUEST - Static variable in class org.onlab.packet.ARP
 
opCode - Variable in class org.onlab.packet.ARP
 
opCode - Variable in class org.onlab.packet.DHCP
 
OPCODE_REPLY - Static variable in class org.onlab.packet.DHCP
 
OPCODE_REQUEST - Static variable in class org.onlab.packet.DHCP
 
OPENED - org.onosproject.store.primitives.PartitionEvent.Type
Signifies that a partition has been successfully opened.
operation(DomainIntentOperation) - Method in class org.onosproject.net.domain.DomainIntentOperations.Builder
Appends an existing domain intent to the current stage.
operation(FlowRuleOperation) - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
Appends an existing flow rule to the current stage.
operations() - Method in class org.onosproject.net.group.GroupOperations
Returns immutable list of group operation.
operations() - Method in class org.onosproject.net.meter.MeterOperations
Returns immutable list of Meter operation.
operator() - Method in class org.onosproject.net.flow.BatchOperationEntry
Gets the operator of this operation.
OPLINK_ATTENUATION - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
ops() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchRequest
Deprecated.
 
OPT_ADDRLIST - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
OPT_CODE_LEN - Static variable in class org.onlab.packet.dhcp.DhcpOption
 
OPT_CODE_LEN - Static variable in class org.onlab.packet.RIPngEntry
 
OPT_GENID - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
OPT_HOLDTIME - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
OPT_PRIORITY - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
OPT_PRUNEDELAY - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
OPTICAL - org.onosproject.net.Link.Type
Signifies that this link is realized by fiber (either single channel or WDM).
OPTICAL_AMPLIFIER - org.onosproject.net.Device.Type
 
OPTICAL_WAVES - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the number of optical waves.
OpticalCircuitIntent - Class in org.onosproject.net.intent
An optical layer intent for circuits between two OduClt ports.
OpticalCircuitIntent() - Constructor for class org.onosproject.net.intent.OpticalCircuitIntent
Constructor for serializer.
OpticalCircuitIntent(ApplicationId, Key, ConnectPoint, ConnectPoint, CltSignalType, boolean, Optional<OchSignal>, Optional<Path>, int, ResourceGroup) - Constructor for class org.onosproject.net.intent.OpticalCircuitIntent
Creates an optical circuit intent between the specified connection points.
OpticalCircuitIntent.Builder - Class in org.onosproject.net.intent
Builder for optical circuit intents.
OpticalConnectivityIntent - Class in org.onosproject.net.intent
An optical layer intent for connectivity between two OCh ports.
OpticalConnectivityIntent() - Constructor for class org.onosproject.net.intent.OpticalConnectivityIntent
Constructor for serializer.
OpticalConnectivityIntent(ApplicationId, Key, ConnectPoint, ConnectPoint, OduSignalType, boolean, Optional<OchSignal>, Optional<Path>, int, ResourceGroup) - Constructor for class org.onosproject.net.intent.OpticalConnectivityIntent
Creates an optical connectivity intent between the specified connection points.
OpticalConnectivityIntent.Builder - Class in org.onosproject.net.intent
Builder for optical connectivity intents.
OpticalConnectPointCompleter - Class in org.onosproject.cli.net
Optical ConnectPoint completer.
OpticalConnectPointCompleter() - Constructor for class org.onosproject.cli.net.OpticalConnectPointCompleter
 
OpticalOduIntent - Class in org.onosproject.net.intent
An optical layer intent between two OduClt ports - in an OTN Topology.
OpticalOduIntent() - Constructor for class org.onosproject.net.intent.OpticalOduIntent
Constructor for serializer.
OpticalOduIntent(ApplicationId, Key, ConnectPoint, ConnectPoint, CltSignalType, boolean, int, ResourceGroup) - Constructor for class org.onosproject.net.intent.OpticalOduIntent
Creates an optical ODU intent between the specified connection points.
OpticalOduIntent.Builder - Class in org.onosproject.net.intent
Builder for optical ODU intents.
OpticalPathIntent - Class in org.onosproject.net.intent
An optical layer intent with explicitly selected path.
OpticalPathIntent() - Constructor for class org.onosproject.net.intent.OpticalPathIntent
 
OpticalPathIntent.Builder - Class in org.onosproject.net.intent
Builder for optical path intents.
OptimisticConcurrencyFailure() - Constructor for exception org.onosproject.store.service.TransactionException.OptimisticConcurrencyFailure
 
Option_Assigned - org.onosproject.dhcp.IpAssignment.AssignmentStatus
IP has been assigned to a host.
OPTION_ERO - org.onlab.packet.DHCP6.OptionCode
 
Option_Expired - org.onosproject.dhcp.IpAssignment.AssignmentStatus
IP mapping is no longer active.
Option_RangeNotEnforced - org.onosproject.dhcp.IpAssignment.AssignmentStatus
Static IP Assignment with unregistered IP range.
Option_Requested - org.onosproject.dhcp.IpAssignment.AssignmentStatus
IP has been requested by a host, but not assigned to it yet.
OPTIONAL - org.onosproject.net.config.Config.FieldPresence
Signifies that config field is an optional one.
OPTIONAL - org.onosproject.net.pi.model.PiMatchType
Optional match type.
optionalTLVList - Variable in class org.onlab.packet.LLDP
 
OptionCode_BroadcastAddress - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_CircuitID - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_Classless_Static_Route - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_ClientID - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_DHCPServerIp - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_DomainName - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_DomainServer - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_END - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_HostName - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_LeaseTime - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_MessageType - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_MTU - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_Pad - org.onlab.packet.DHCP.DHCPOptionCode
 
OPtionCode_RebindingTime - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_RenewalTime - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_RequestedIP - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_RequestedParameters - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_RouterAddress - org.onlab.packet.DHCP.DHCPOptionCode
 
OptionCode_SubnetMask - org.onlab.packet.DHCP.DHCPOptionCode
 
options - Variable in class org.onlab.packet.DHCP
 
options - Variable in class org.onlab.packet.IPv4
 
options - Variable in class org.onlab.packet.ipv6.BaseOptions
 
options - Variable in class org.onlab.packet.TCP
 
options() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
Gets the Neighbor Discovery Protocol packet options.
opType() - Method in class org.onosproject.net.group.GroupOperation
Returns group operation type.
OR - org.onlab.util.StringFilter.Strategy
 
ORDER - org.onosproject.net.intent.constraint.TierConstraint.CostType
Configures the constraint to return the order the tier value was added to the list of included tiers on the constraint.
OrderedExecutor - Class in org.onlab.util
Executor that executes tasks in order on a shared thread pool.
OrderedExecutor(Executor) - Constructor for class org.onlab.util.OrderedExecutor
 
orderedFuture(CompletableFuture<T>, Executor, Executor) - Static method in class org.onlab.util.Tools
Returns a future that's completed using the given orderedExecutor if the future is not blocked or the given threadPoolExecutor if the future is blocked.
ordering() - Method in class org.onosproject.store.service.DocumentTreeOptions
Returns the ordering of tree nodes.
Ordering - Enum in org.onosproject.store.service
Describes the order of a primitive data structure.
org.onlab.graph - package org.onlab.graph
Graph abstractions and graph path finding algorithms.
org.onlab.junit - package org.onlab.junit
Utilities to assist in developing JUnit tests.
org.onlab.metrics - package org.onlab.metrics
Misc utils for various performance metrics.
org.onlab.osgi - package org.onlab.osgi
Facilities for building testable components in OSGi independent fashion.
org.onlab.packet - package org.onlab.packet
Utilities for decoding and encoding packets of various network protocols and encapsulations.
org.onlab.packet.bmp - package org.onlab.packet.bmp
Utility for decoding bmp options.
org.onlab.packet.dhcp - package org.onlab.packet.dhcp
Utilities for decoding and encoding DHCP options.
org.onlab.packet.ipv6 - package org.onlab.packet.ipv6
Utilities for decoding and encoding IPv6 extension headers.
org.onlab.packet.lacp - package org.onlab.packet.lacp
Utilities for decoding and encoding LACP packets.
org.onlab.packet.ndp - package org.onlab.packet.ndp
Utilities for decoding and encoding packets of Neighbor Discovery Protocol for IPv6 (RFC 4861).
org.onlab.packet.pim - package org.onlab.packet.pim
Utilities for managing PIM packets.
org.onlab.rest - package org.onlab.rest
Facilities for building JAX-RS web resources.
org.onlab.rest.exceptions - package org.onlab.rest.exceptions
Various exception mappers to map errors to proper response status codes.
org.onlab.util - package org.onlab.util
Miscellaneous domain-agnostic utilities.
org.onosproject.alarm - package org.onosproject.alarm
Abstractions for interacting with alarms.
org.onosproject.app - package org.onosproject.app
Set of abstractions for managing network control applications.
org.onosproject.cfg - package org.onosproject.cfg
Set of abstractions for centrally managing component configurations.
org.onosproject.cli - package org.onosproject.cli
Administrative console command-line extensions.
org.onosproject.cli.app - package org.onosproject.cli.app
CLI commands for managing distributed inventory of applications.
org.onosproject.cli.cfg - package org.onosproject.cli.cfg
CLI commands for managing centralized component and network configurations.
org.onosproject.cli.net - package org.onosproject.cli.net
Administrative console command-line extensions for interacting with the network model & services.
org.onosproject.cli.net.completer - package org.onosproject.cli.net.completer
Completers for karaf CLI.
org.onosproject.cli.security - package org.onosproject.cli.security
CLI commands for managing security permissions.
org.onosproject.cluster - package org.onosproject.cluster
Set of abstractions for dealing with controller cluster related topics.
org.onosproject.codec - package org.onosproject.codec
Base JSON codec abstraction and a service for tracking various JSON codecs.
org.onosproject.common - package org.onosproject.common
Miscellaneous common facilities used for construction of various core and app subsystems.
org.onosproject.common.app - package org.onosproject.common.app
Common facilities for construction of application management subsystem.
org.onosproject.common.net - package org.onosproject.common.net
Set of common network core facilities.
org.onosproject.component - package org.onosproject.component
Component management system.
org.onosproject.core - package org.onosproject.core
ONOS Core API definitions.
org.onosproject.cpman - package org.onosproject.cpman
An application that manages the control plane.
org.onosproject.cpman.message - package org.onosproject.cpman.message
Service for looking up control message stats.
org.onosproject.dhcp - package org.onosproject.dhcp
Sample application that assigns and manages DHCP leases.
org.onosproject.event - package org.onosproject.event
Local event delivery subsystem interfaces & supporting abstractions.
org.onosproject.mastership - package org.onosproject.mastership
Set of abstractions for dealing with controller mastership related topics.
org.onosproject.net - package org.onosproject.net
Constants for OSGi properties in the core/net components.
org.onosproject.net.behaviour - package org.onosproject.net.behaviour
Abstractions of various device configuration or device adaptation behaviours; counterpart to the device driver subsystem.
org.onosproject.net.behaviour.inbandtelemetry - package org.onosproject.net.behaviour.inbandtelemetry
Behaviors abstracting devices supporting in-band network telemetry.
org.onosproject.net.behaviour.protection - package org.onosproject.net.behaviour.protection
Protection behaviour and related classes.
org.onosproject.net.behaviour.trafficcontrol - package org.onosproject.net.behaviour.trafficcontrol
Traffic control behaviors and related classes.
org.onosproject.net.behaviour.upf - package org.onosproject.net.behaviour.upf
3GPP User Plane Function behaviors and related classes.
org.onosproject.net.config - package org.onosproject.net.config
Subsystem for tracking network environment configuration.
org.onosproject.net.config.basics - package org.onosproject.net.config.basics
Various basic builtin network configurations.
org.onosproject.net.config.inject - package org.onosproject.net.config.inject
Network configurations for "inject" provider.
org.onosproject.net.device - package org.onosproject.net.device
Infrastructure device model & related services API definitions.
org.onosproject.net.domain - package org.onosproject.net.domain
Domain intent package.
org.onosproject.net.driver - package org.onosproject.net.driver
Set of facilities to allow the platform to be extended with device specific behaviours and to allow modeling device (and other entity) behaviours while hiding details of specific driver implementations.
org.onosproject.net.edge - package org.onosproject.net.edge
Service for interacting with network edge.
org.onosproject.net.flow - package org.onosproject.net.flow
Flow rule model & related services API definitions.
org.onosproject.net.flow.criteria - package org.onosproject.net.flow.criteria
Traffic selection criteria model.
org.onosproject.net.flow.instructions - package org.onosproject.net.flow.instructions
Traffic treatment model.
org.onosproject.net.flow.oldbatch - package org.onosproject.net.flow.oldbatch
Flow rule model & related services API definitions.
org.onosproject.net.flowobjective - package org.onosproject.net.flowobjective
Abstractions for objective-based flow programming of data plane without requiring device pipeline structure awareness.  This subsystem is experimental and its interfaces will change in the upcoming release.
org.onosproject.net.group - package org.onosproject.net.group
Abstractions for interacting with device port groups.
org.onosproject.net.host - package org.onosproject.net.host
End-station host model & related services API definitions.
org.onosproject.net.intent - package org.onosproject.net.intent
Set of abstractions for conveying high-level intents for treatment of selected network traffic by allowing applications to express the what rather than the how.
org.onosproject.net.intent.constraint - package org.onosproject.net.intent.constraint
Definitions of constraints used to refine intent specifications.
org.onosproject.net.intent.util - package org.onosproject.net.intent.util
Package supports intent northbound apis providing utility classes.
org.onosproject.net.intf - package org.onosproject.net.intf
Interface Service.
org.onosproject.net.key - package org.onosproject.net.key
Device key data model and services.
org.onosproject.net.link - package org.onosproject.net.link
Infrastructure link model & related services API definitions.
org.onosproject.net.mcast - package org.onosproject.net.mcast
External model entities of the multicast RIB.
org.onosproject.net.meter - package org.onosproject.net.meter
Flow meter model and related services.
org.onosproject.net.neighbour - package org.onosproject.net.neighbour
Neighbour message (ARP, NDP) handling.
org.onosproject.net.packet - package org.onosproject.net.packet
Mechanism for processing inbound packets intercepted from the data plane and for emitting outbound packets onto the data plane.
org.onosproject.net.packet.packetfilter - package org.onosproject.net.packet.packetfilter
Packet filter classifier for various Packet types.
org.onosproject.net.pi.model - package org.onosproject.net.pi.model
Model abstractions of a protocol-independent packet processing pipeline.
org.onosproject.net.pi.runtime - package org.onosproject.net.pi.runtime
Classes abstracting entities for runtime control of a protocol-independent packet processing pipeline.
org.onosproject.net.pi.runtime.data - package org.onosproject.net.pi.runtime.data
Classes abstracting data that can be used for runtime operations of a protocol-independent pipeline.
org.onosproject.net.pi.service - package org.onosproject.net.pi.service
Service abstractions for runtime control of a protocol-independent pipeline.
org.onosproject.net.provider - package org.onosproject.net.provider
Base abstractions related to network entity providers and their brokers.
org.onosproject.net.proxyarp - package org.onosproject.net.proxyarp
Base abstractions related to the proxy arp service.
org.onosproject.net.region - package org.onosproject.net.region
Subsystem for tracking inventory of network control regions.
org.onosproject.net.resource - package org.onosproject.net.resource
Generic network resource model and services for resource allocation and resource tracking.
org.onosproject.net.statistic - package org.onosproject.net.statistic
Service for looking up statistics on links.
org.onosproject.net.topology - package org.onosproject.net.topology
Network topology model & related services API definitions.
org.onosproject.net.utils - package org.onosproject.net.utils
Utility classes.
org.onosproject.persistence - package org.onosproject.persistence
Persistence service and builders.
org.onosproject.rest - package org.onosproject.rest
Base abstractions and utilities for developing REST APIs.
org.onosproject.routing - package org.onosproject.routing
API for routing libraries.
org.onosproject.routing.config - package org.onosproject.routing.config
Routing configuration interfaces.
org.onosproject.security - package org.onosproject.security
Application security constructs.
org.onosproject.store - package org.onosproject.store
Stores used by the core of ONOS.
org.onosproject.store.app - package org.onosproject.store.app
Implementation of distributed application store.
org.onosproject.store.atomix - package org.onosproject.store.atomix
Subsystem for tracking controller cluster nodes.
org.onosproject.store.cfg - package org.onosproject.store.cfg
Implementation of distributed component configuration store.
org.onosproject.store.cluster.messaging - package org.onosproject.store.cluster.messaging
Cluster messaging APIs for the use by the various distributed stores.
org.onosproject.store.flow - package org.onosproject.store.flow
Definitions of events and messages pertaining to replication of flow entries.
org.onosproject.store.primitives - package org.onosproject.store.primitives
Interfaces for creating various distributed primitives.
org.onosproject.store.serializers - package org.onosproject.store.serializers
Various Kryo serializers for use in distributed stores.
org.onosproject.store.serializers.custom - package org.onosproject.store.serializers.custom
Distributed store serializers.
org.onosproject.store.service - package org.onosproject.store.service
Distributed core state management services.
org.onosproject.ui - package org.onosproject.ui
Mechanism for managing dynamically registered user interface extensions.
org.onosproject.ui.chart - package org.onosproject.ui.chart
Facilities for creating chart models of data for the Web UI.
org.onosproject.ui.lion - package org.onosproject.ui.lion
Facilities for handling localization of the UI.
org.onosproject.ui.model - package org.onosproject.ui.model
Server-side modeling of UI entities.
org.onosproject.ui.model.topo - package org.onosproject.ui.model.topo
Server-side modeling of Topology View UI entities.
org.onosproject.ui.table - package org.onosproject.ui.table
Facilities for creating tabular models of data for the GUI.
org.onosproject.ui.table.cell - package org.onosproject.ui.table.cell
Set of table cell renderers and comparators for use by GUI apps.
org.onosproject.ui.topo - package org.onosproject.ui.topo
Mechanism for dynamically extending topology view with information and behaviour overlays.
org.onosproject.upgrade - package org.onosproject.upgrade
Abstractions for managing software upgrades.
org.onosproject.utils - package org.onosproject.utils
Miscellaneous common facilities used for construction of various core and app subsystems.
ORGANIZATIONAL_TLV_TYPE - Static variable in class org.onlab.packet.LLDPOrganizationalTLV
 
origin() - Method in interface org.onosproject.app.ApplicationDescription
Returns the name of the application origin, group or company.
origin() - Method in class org.onosproject.app.DefaultApplicationDescription
 
origin() - Method in interface org.onosproject.core.Application
Returns the name of the application origin, group or company.
origin() - Method in class org.onosproject.core.DefaultApplication
 
origin() - Method in class org.onosproject.net.intent.IntentData
Returns the origin node that created this intent.
original() - Method in class org.onosproject.net.pi.service.PiTranslatedEntity
Returns the original PD entity.
original() - Method in class org.onosproject.ui.model.topo.UiSynthLink
Returns the original link from which this was derived.
orNull(byte[]) - Static method in class org.onlab.util.ByteArraySizeHashPrinter
Returns ByteArraySizeHashPrinter wrapping given byte[].
ORO - org.onlab.packet.DHCP6.OptionCode
 
OsgiPropertyConstants - Class in org.onosproject.net
 
OsgiPropertyConstants - Class in org.onosproject.store
Name/Value constants for properties.
ospfEnabled() - Method in class org.onosproject.routing.RouterInfo
Returns whether OSPF is enabled on the router.
OTHER - org.onosproject.net.Device.Type
 
OTHER - org.onosproject.ui.UiView.Category
Represents miscellaneous views.
otherConfigs(SparseAnnotations) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
otherConfigs(SparseAnnotations) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface descriptions builder with other configurations.
OTN - org.onosproject.net.Device.Type
 
OTN - Static variable in class org.onosproject.ui.GlyphConstants
 
OTU - org.onosproject.net.Port.Type
Signifies optical fiber-based OTN port.
OTU1 - org.onosproject.net.OtuSignalType
 
OTU2 - org.onosproject.net.OtuSignalType
 
OTU3 - org.onosproject.net.OtuSignalType
 
OTU4 - org.onosproject.net.OtuSignalType
 
OtuSignalType - Enum in org.onosproject.net
Represents OTU (Optical channel Transport Unit) signal type.
oui - Variable in class org.onlab.packet.LLDPOrganizationalTLV
 
oui() - Method in class org.onlab.packet.MacAddress
Returns the Organizationally Unique Identifier (OUI) of this MAC address.
OUI_LENGTH - Static variable in class org.onlab.packet.LLDPOrganizationalTLV
 
OUT_OF_BANDS - org.onosproject.net.meter.MeterFailReason
The device does not support any more bands for this meter.
OUT_OF_BUCKETS - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
OUT_OF_GROUPS - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
OUT_OF_METERS - org.onosproject.net.meter.MeterFailReason
The device does not support any more meters.
OUTBOUND_PACKET - org.onosproject.cpman.ControlMessage.Type
 
OUTBOUND_PACKET - org.onosproject.cpman.ControlMetricType
 
OutboundPacket - Interface in org.onosproject.net.packet
Represents an outbound data packet that is to be emitted to network via an infrastructure device.
outerTpid() - Method in class org.onosproject.net.config.basics.BasicHostConfig
 
outPacket() - Method in class org.onosproject.net.packet.DefaultPacketContext
 
outPacket() - Method in interface org.onosproject.net.packet.PacketContext
Returns the view of the outbound packet.
output() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription
 
OUTPUT - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be output to a port.
outputJson() - Method in class org.onosproject.cli.AbstractShellCommand
Indicates whether JSON format should be output.
outputPort() - Method in class org.onosproject.net.PipelineTraceableHitChain
Returns the output connect point.
overrideFlag - Variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
ownedTopics(NodeId) - Method in interface org.onosproject.cluster.LeadershipService
Returns the set of topics owned by the specified node.
owner() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns owner of the element.
owner(String) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the owner of the element.
OWNER - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for device owner.
OWNER - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for owner.
OX - Static variable in class org.onosproject.ui.table.cell.AbstractCellFormatter
 

P

P0 - Static variable in class org.onosproject.net.PortNumber
 
P4_INFO_TEXT - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
The P4Info as returned by the p4c compiler in text format.
packet() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the full parsed representation of the packet.
packet() - Method in class org.onosproject.net.PipelineTraceablePacket
Getter for the packet selector.
PACKET - org.onosproject.net.Port.Type
Signifies optical fiber-based packet port.
PACKET_ALLOW - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that the packet is allowed to be processed.
PACKET_BLOCKED - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that the packet processing is blocked as the threshold has crossed.
PACKET_COUNT - org.onosproject.net.flow.StatTriggerField
Number of packets in flow entry.
PACKET_DENY - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that the packet is denied from being processed as it crossed the maxCounter.
PACKET_EVENT - org.onosproject.security.AppPermission.Type
 
PACKET_IN - org.onosproject.net.pi.model.PiPacketOperationType
Represents a packet-in, i.e.
PACKET_OUT - org.onosproject.net.pi.model.PiPacketOperationType
Represents a packet-out, i.e.
PACKET_READ - org.onosproject.security.AppPermission.Type
 
PACKET_TYPE - org.onosproject.net.flow.criteria.Criterion.Type
Packet type value.
PACKET_WRITE - org.onosproject.security.AppPermission.Type
 
PacketContext - Interface in org.onosproject.net.packet
Represents context for processing an inbound packet, and (optionally) emitting a corresponding outbound packet.
PacketDetectionRule - Class in org.onosproject.net.behaviour.upf
A single Packet Detection Rule (PDR), an entity described in the 3GPP specifications (although that does not mean that this class is 3GPP compliant).
PacketDetectionRule.Builder - Class in org.onosproject.net.behaviour.upf
 
PacketEvent - Class in org.onosproject.net.packet
Describes a packet event.
PacketEvent(PacketEvent.Type, OutboundPacket) - Constructor for class org.onosproject.net.packet.PacketEvent
Creates an event of the given type for the specified packet.
PacketEvent(PacketEvent.Type, OutboundPacket, long) - Constructor for class org.onosproject.net.packet.PacketEvent
Creates an event of the given type for the specified packet at the given time.
PacketEvent.Type - Enum in org.onosproject.net.packet
Type of packet events.
PacketInClassifier - Interface in org.onosproject.net.packet
Abstraction of incoming packet classifier for filtering.
PacketInFilter - Interface in org.onosproject.net.packet
Abstraction of incoming packet filter.
PacketInFilter.FilterAction - Enum in org.onosproject.net.packet
Types of filter action applied to incoming packets.
packetLength() - Method in class org.onlab.packet.EAPOLMkpdu
Total EAPOL-MKPDU packet length.
packetOperationModel(PiPacketOperationType) - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns the packet operation model of the given type, if present.
PacketPriority - Enum in org.onosproject.net.packet
Priorities available to applications for requests for packets from the data plane.
PacketProcessor - Interface in org.onosproject.net.packet
Abstraction of an inbound packet processor.
PacketProcessorEntry - Interface in org.onosproject.net.packet
Packet processor entry tracking the processor, its priority and time consumption.
PacketProcessorsListCommand - Class in org.onosproject.cli.net
Lists packet processors.
PacketProcessorsListCommand() - Constructor for class org.onosproject.cli.net.PacketProcessorsListCommand
 
PacketProgrammable - Interface in org.onosproject.net.packet
Packet programmable device behaviour.
PacketProvider - Interface in org.onosproject.net.packet
Abstraction of a packet provider capable of emitting packets.
PacketProviderRegistry - Interface in org.onosproject.net.packet
Abstraction of an infrastructure packet provider registry.
PacketProviderService - Interface in org.onosproject.net.packet
Entity capable of processing inbound packets.
PacketRequest - Interface in org.onosproject.net.packet
Represents a packet request made to devices.
PacketRequestsListCommand - Class in org.onosproject.cli.net
Lists packet requests.
PacketRequestsListCommand() - Constructor for class org.onosproject.cli.net.PacketRequestsListCommand
 
packets() - Method in class org.onosproject.net.behaviour.MirroringStatistics
Returns the transmitted packtes.
packets() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
packets() - Method in interface org.onosproject.net.flow.FlowEntry
Returns the number of packets this flow rule has matched.
packets() - Method in class org.onosproject.net.group.DefaultGroup
Returns the number of packets processed by this group.
packets() - Method in class org.onosproject.net.group.DefaultGroupBucket
 
packets() - Method in interface org.onosproject.net.group.Group
Returns the number of packets processed by this group.
packets() - Method in interface org.onosproject.net.group.GroupBucket
Returns the number of packets processed by this group bucket.
packets() - Method in interface org.onosproject.net.meter.Band
Returns the packets seen by this band.
packets() - Method in class org.onosproject.net.meter.DefaultBand
 
packets() - Method in class org.onosproject.net.pi.runtime.PiCounterCellData
Returns the packet count value contained by this counter data.
PACKETS - org.onosproject.net.pi.model.PiCounterModel.Unit
Counts only packets.
PACKETS - org.onosproject.net.pi.model.PiMeterModel.Unit
Measures rate of packets.
PACKETS - org.onosproject.net.statistic.PortStatisticsService.MetricType
Load is to be given in packets/second.
PACKETS_AND_BYTES - org.onosproject.net.pi.model.PiCounterModel.Unit
Counts both packets and bytes.
PACKETS_UNIT - Static variable in class org.onosproject.ui.topo.TopoUtils
 
PacketService - Interface in org.onosproject.net.packet
Service for intercepting data plane packets and for emitting synthetic outbound packets.
packetsLookedup() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
packetsLookedup() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
Returns the number of packets looked up in the table.
packetsMatched() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
packetsMatched() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
Returns the number of packets that successfully matched in the table.
packetsReceived() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
packetsReceived() - Method in interface org.onosproject.net.device.PortStatistics
Returns the number of packets received.
packetsRxDropped() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
packetsRxDropped() - Method in interface org.onosproject.net.device.PortStatistics
Returns the number of packets dropped by RX.
packetsRxErrors() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
packetsRxErrors() - Method in interface org.onosproject.net.device.PortStatistics
Returns the number of transmit errors.
packetsSeen() - Method in class org.onosproject.net.meter.DefaultMeter
 
packetsSeen() - Method in interface org.onosproject.net.meter.Meter
Number of packets processed by this meter.
packetsSent() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
packetsSent() - Method in interface org.onosproject.net.device.PortStatistics
Returns the number of packets sent.
PacketStore - Interface in org.onosproject.net.packet
Manages routing of outbound packets.
PacketStoreDelegate - Interface in org.onosproject.net.packet
Packet store delegate abstraction.
packetsTxDropped() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
packetsTxDropped() - Method in interface org.onosproject.net.device.PortStatistics
Returns the number of packets dropped by TX.
packetsTxErrors() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
packetsTxErrors() - Method in interface org.onosproject.net.device.PortStatistics
Returns the number of receive errors.
PacketUtils - Class in org.onlab.packet
Utilities for working with packet headers.
pad - Variable in class org.onlab.packet.Ethernet
 
PADI - org.onlab.packet.PPPoED.Type
 
PADO - org.onlab.packet.PPPoED.Type
 
PADR - org.onlab.packet.PPPoED.Type
 
PADS - org.onlab.packet.PPPoED.Type
 
PADT - org.onlab.packet.PPPoED.Type
 
PAE_GROUP_ADDR - Static variable in class org.onlab.packet.EAPOL
 
parallelStream() - Method in class org.onlab.util.UnmodifiableDeque
 
param(PiActionParamId) - Method in interface org.onosproject.net.pi.model.PiActionModel
Returns the model of the action's parameter defined by the given ID, if present.
PARAM_ERR - org.onosproject.cli.net.Icmp6Type
Parameter Problem.
PARAM_ERR - Static variable in class org.onlab.packet.ICMP6
Parameter Problem.
parameters() - Method in class org.onosproject.net.pi.runtime.PiAction
Returns all runtime parameters of this action.
PARAMETERSET_TYPE_BASIC - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
PARAMETERSET_TYPE_DISTRIBUTED_SAK - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
PARAMETERSET_TYPE_ICV_INDICATOR - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
PARAMETERSET_TYPE_LIVE_PEER_LIST - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
PARAMETERSET_TYPE_MACSEC_SAK_USE - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
PARAMETERSET_TYPE_POTENTIAL_PEER_LIST - Static variable in interface org.onlab.packet.EAPOLMkpduParameterSet
 
params() - Method in interface org.onosproject.net.pi.model.PiActionModel
Returns the collection of all parameter models for the action, or an empty collection if this action has no parameters.
parent - Variable in class org.onlab.packet.BasePacket
 
parent() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the identifier of the parent layout.
parent() - Method in class org.onosproject.net.driver.DefaultDriver
 
parent() - Method in interface org.onosproject.net.driver.Driver
Deprecated.
1.5.0 Falcon Release
parent() - Method in class org.onosproject.net.resource.ContinuousResource
 
parent() - Method in class org.onosproject.net.resource.ContinuousResourceId
 
parent() - Method in class org.onosproject.net.resource.DiscreteResource
 
parent() - Method in class org.onosproject.net.resource.DiscreteResourceId
 
parent() - Method in interface org.onosproject.net.resource.Resource
Returns the parent resource of this instance.
parent() - Method in class org.onosproject.net.resource.ResourceId
Returns the parent resource ID of this instance.
parent() - Method in class org.onosproject.store.service.DocumentPath
Returns a path for the parent of this node.
parent() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the identity of the parent region.
parent() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the parent layout identifier.
parent(UiTopoLayoutId) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the identifier of the parent layout.
parent(UiTopoLayoutId) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the identity of this layout's parent.
parentRegion() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the UI region that is the parent of this region.
parents - Variable in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
parents() - Method in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
parents() - Method in interface org.onlab.graph.GraphPathSearch.Result
Returns bindings of each vertex to its parent edges in the path.
parents() - Method in class org.onosproject.net.driver.DefaultDriver
 
parents() - Method in interface org.onosproject.net.driver.Driver
Returns all the parent drivers from which this driver inherits behaviours and properties.
parsed() - Method in class org.onosproject.net.packet.DefaultInboundPacket
 
parsed() - Method in interface org.onosproject.net.packet.InboundPacket
Returns the parsed form of the packet.
parseFromString(String) - Static method in enum org.onosproject.cli.net.EthType
Parse a string input that could contain an EthType value.
parseFromString(String) - Static method in enum org.onosproject.cli.net.ExtHeader
Parse a string input that could contain an ExtHeader value.
parseFromString(String) - Static method in enum org.onosproject.cli.net.Icmp6Code
Parse a string input that could contain an Icmp6Code value.
parseFromString(String) - Static method in enum org.onosproject.cli.net.Icmp6Type
Parse a string input that could contain an Icmp6Type value.
parseFromString(String) - Static method in enum org.onosproject.cli.net.IpProtocol
Parse a string input that could contain an IpProtocol value.
parseLLDP(Ethernet) - Static method in class org.onlab.packet.ONOSLLDP
Given an ethernet packet, returns the device the LLDP came from.
parseONOSLLDP(Ethernet) - Static method in class org.onlab.packet.ONOSLLDP
Given an ethernet packet, determines if this is an LLDP from ONOS and returns the device the LLDP came from.
parseShort(short) - Static method in enum org.onosproject.net.flow.FlowRule.FlowRemoveReason
Covert short to enum.
PartialFailureConstraint - Class in org.onosproject.net.intent.constraint
A constraint that allows intents that can only be partially compiled (i.e.
PartialFailureConstraint() - Constructor for class org.onosproject.net.intent.constraint.PartialFailureConstraint
 
Partition - Interface in org.onosproject.cluster
A partition or shard is a group of controller nodes that are work together to maintain state.
PARTITION_EVENT - org.onosproject.security.AppPermission.Type
 
PARTITION_READ - org.onosproject.security.AppPermission.Type
 
PartitionAdminService - Interface in org.onosproject.store.primitives
Administrative interface for partition membership changes.
partitionClientInfo() - Method in interface org.onosproject.store.primitives.PartitionAdminService
Returns the information for partition clients.
PartitionClientInfo - Class in org.onosproject.store.service
Contains information about a database partition client.
PartitionClientInfo(PartitionId, Collection<NodeId>) - Constructor for class org.onosproject.store.service.PartitionClientInfo
 
PartitionDiff - Class in org.onosproject.cluster
Utility for examining differences between two partition values.
PartitionDiff(Partition, Partition) - Constructor for class org.onosproject.cluster.PartitionDiff
 
partitionDiffs() - Method in class org.onosproject.cluster.ClusterMetadataDiff
Deprecated.
Returns a mapping of all partition diffs.
PartitionEvent - Class in org.onosproject.store.primitives
Describes partition-related event.
PartitionEvent(PartitionEvent.Type, Partition, long) - Constructor for class org.onosproject.store.primitives.PartitionEvent
Creates an event of a given type and for the specified partition and time.
PartitionEvent.Type - Enum in org.onosproject.store.primitives
Type of partition-related events.
PartitionEventListener - Interface in org.onosproject.store.primitives
Entity capable of receiving partition-related events.
partitionId() - Method in class org.onosproject.cluster.PartitionDiff
Returns the new partition identifier.
partitionId() - Method in class org.onosproject.store.service.PartitionClientInfo
Returns the identifier for the partition.
PartitionId - Class in org.onosproject.cluster
Partition identifier.
PartitionId(int) - Constructor for class org.onosproject.cluster.PartitionId
Creates a partition identifier from an integer.
partitionInfo() - Method in interface org.onosproject.store.primitives.PartitionAdminService
Returns the information for existing partitions.
PartitionInfo - Class in org.onosproject.store.service
Contains information about a database partition.
PartitionInfo(PartitionId, long, List<String>, String) - Constructor for class org.onosproject.store.service.PartitionInfo
Class constructor.
partitionsDisabled() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns if partitions are disabled.
PartitionService - Interface in org.onosproject.store.primitives
Service used for accessing information about storage partitions.
PartitionsListCommand - Class in org.onosproject.cli.net
Command to list the database partitions in the system.
PartitionsListCommand() - Constructor for class org.onosproject.cli.net.PartitionsListCommand
 
PartitionsSnapshotCommand - Class in org.onosproject.cli.net
Command to force a snapshot of the partitions.
PartitionsSnapshotCommand() - Constructor for class org.onosproject.cli.net.PartitionsSnapshotCommand
 
pass() - Method in class org.onosproject.net.PipelineTraceableHitChain
Unset the dropped flag.
PASS - org.onosproject.net.behaviour.BandwidthProfileAction.Action
Traffic is allowed to pass unmodified.
password() - Method in class org.onosproject.net.key.UsernamePassword
Returns the password.
PASSWORD - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the password.
patch() - Method in class org.onosproject.core.Version
Returns the version patch segment.
PatchDescription - Interface in org.onosproject.net.behaviour
Describes a patch interface.
PatchDescription.Builder - Interface in org.onosproject.net.behaviour
Builder of patch interface description entities.
path() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
path() - Method in class org.onosproject.net.intent.PathIntent
Returns the links which the traffic goes along.
path() - Method in class org.onosproject.store.primitives.NodeUpdate
Returns the item path being updated.
path() - Method in class org.onosproject.store.service.DocumentTreeEvent
Returns the path to the changed node.
path() - Method in interface org.onosproject.store.service.DocumentTreeNode
Returns the path to this node in a DocumentTree.
path() - Method in class org.onosproject.ui.UiGlyph
Returns the path for this glyph.
path(Path) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
Sets the path for the intent that will be built.
path(Path) - Method in class org.onosproject.net.intent.PathIntent.Builder
Sets the path of the intent that will be built.
Path<V extends Vertex,​E extends Edge<V>> - Interface in org.onlab.graph
Representation of a path in a graph as a sequence of edges.
Path - Interface in org.onosproject.net
Representation of a contiguous directed path in a network.
PATH - Static variable in class org.onosproject.ui.GlyphConstants
 
PathAdminService - Interface in org.onosproject.net.topology
Provides administrative abilities to tailor the path service behaviours.
pathElements() - Method in class org.onosproject.store.service.DocumentPath
Returns the list of path elements representing this path in correct order.
PathIntent - Class in org.onosproject.net.intent
Abstraction of explicitly path specified connectivity intent.
PathIntent() - Constructor for class org.onosproject.net.intent.PathIntent
Constructor for serializer.
PathIntent(ApplicationId, Key, TrafficSelector, TrafficTreatment, Path, List<Constraint>, int, PathIntent.ProtectionType, ResourceGroup) - Constructor for class org.onosproject.net.intent.PathIntent
Creates a new point-to-point intent with the supplied ingress/egress ports and using the specified explicit path, which can be classified as PRIMARY or BACKUP.
PathIntent.Builder - Class in org.onosproject.net.intent
Builder of a host to host intent.
PathIntent.ProtectionType - Enum in org.onosproject.net.intent
 
PathListCommand - Class in org.onosproject.cli.net
Lists all shortest-paths paths between the specified source and destination devices.
PathListCommand() - Constructor for class org.onosproject.cli.net.PathListCommand
 
paths - Variable in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
paths() - Method in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
paths() - Method in interface org.onlab.graph.GraphPathSearch.Result
Returns the set of paths produced as a result of the graph search.
paths() - Method in class org.onlab.graph.KShortestPathsSearch.InnerOrderedResult
 
paths() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
Returns List of underlying transport entity endpoints in priority order.
paths() - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
Returns List of underlying transport entity endpoints in priority order.
paths(List<TransportEndpointDescription>) - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
Sets the List of underlying transport entity endpoints in priority order.
PathService - Interface in org.onosproject.net.topology
Service for obtaining pre-computed paths or for requesting computation of paths using the current topology snapshot.
pathStates() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
Returns the TransportEndpointStates forming the ProtectedPathEndPoint.
pathString(Path) - Method in class org.onosproject.cli.net.PathListCommand
Produces a formatted string representing the specified path.
PathViabilityConstraint - Class in org.onosproject.net.intent.constraint
Abstract Constraint for constraints intended to influence only path viability and not influence individual link cost during path computation.
PathViabilityConstraint() - Constructor for class org.onosproject.net.intent.constraint.PathViabilityConstraint
 
payload - Variable in class org.onlab.packet.BasePacket
 
payload() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
Returns the message payload.
payload() - Method in class org.onosproject.store.service.Task
Returns the task payload.
payload(ObjectNode) - Static method in class org.onosproject.ui.JsonUtils
Returns the payload from the specified event.
payloadLength - Variable in class org.onlab.packet.ipv6.Authentication
 
payloadLength - Variable in class org.onlab.packet.IPv6
 
payloadLength - Variable in class org.onlab.packet.PPPoED
 
PBB_ISID - org.onosproject.net.flow.criteria.Criterion.Type
PBB I-SID.
PBB_UCA - org.onosproject.net.flow.criteria.Criterion.Type
PBB UCA header field.
pbbIsid() - Method in class org.onosproject.net.flow.criteria.PbbIsidCriterion
Gets the PBB I-SID to match.
PbbIsidCriterion - Class in org.onosproject.net.flow.criteria
Implementation of PBB I-SID criterion (24 bits unsigned integer).
pbs() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the peak burst size (PBS) of this bandwidth profile.
pbs(Integer) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the peak burst size (PBS) of this builder.
pdrCounterSize() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Return the number of PDR counter cells available.
PdrStats - Class in org.onosproject.net.behaviour.upf
A structure for compactly passing PDR counter values for a given counter ID.
PdrStats.Builder - Class in org.onosproject.net.behaviour.upf
 
pdrTableSize() - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Return the total number of table entries the downlink and uplink PDR tables support.
PEAK - org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Type
Peak rate.
PEAK - org.onosproject.net.pi.runtime.PiMeterBandType
Peak band config.
peakBand() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
Returns the peak configuration if present.
peek() - Method in class org.onlab.util.UnmodifiableDeque
 
peekFirst() - Method in class org.onlab.util.UnmodifiableDeque
 
peekLast() - Method in class org.onlab.util.UnmodifiableDeque
 
peer() - Method in class org.onosproject.net.behaviour.DefaultPatchDescription
 
peer() - Method in interface org.onosproject.net.behaviour.PatchDescription
Returns the name of the interface for the other side of the patch.
peer() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
Returns DeviceId of remote peer of this endpoint.
peer() - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
Returns DeviceId of remote peer of this endpoint.
peer(String) - Method in class org.onosproject.net.behaviour.DefaultPatchDescription.Builder
 
peer(String) - Method in interface org.onosproject.net.behaviour.PatchDescription.Builder
Returns patch interface description builder with a given peer.
peer(DeviceId) - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
Sets the DeviceId of remote peer of this endpoint.
PEER_DISTINGUISHER - Static variable in class org.onlab.packet.bmp.BmpPeer
 
PEER_HEADER_MINIMUM_LENGTH - Static variable in class org.onlab.packet.bmp.BmpPeer
 
peerAddress - Variable in class org.onlab.packet.bmp.BmpPeer
 
peerAddress() - Method in class org.onosproject.net.host.InterfaceIpAddress
Gets the IP point-to-point interface peer address.
peerAs - Variable in class org.onlab.packet.bmp.BmpPeer
 
peerBgpId - Variable in class org.onlab.packet.bmp.BmpPeer
 
PeerConnectPointCompleter - Class in org.onosproject.cli.net.completer
Completer, which proposes remote end of existing Link in the system.
PeerConnectPointCompleter() - Constructor for class org.onosproject.cli.net.completer.PeerConnectPointCompleter
 
peerDistinguisher - Variable in class org.onlab.packet.bmp.BmpPeer
 
peers() - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
 
PEERS - Static variable in class org.onosproject.routing.config.BgpConfig
 
PENDING_ADD - org.onosproject.net.flow.FlowEntry.FlowEntryState
Indicates that this rule has been submitted for addition.
PENDING_ADD - org.onosproject.net.group.Group.GroupState
Group create request is processed by ONOS and not yet received the confirmation from data plane.
PENDING_ADD - org.onosproject.net.meter.MeterState
The meter is in the process of being added.
PENDING_ADD_RETRY - org.onosproject.net.group.Group.GroupState
Group is missing in data plane and retrying GROUP ADD request.
PENDING_DELETE - org.onosproject.net.group.Group.GroupState
Group delete request is processed by ONOS and not received the confirmation from data plane.
PENDING_REMOVE - org.onosproject.net.flow.FlowEntry.FlowEntryState
Flow has been marked for removal, might still be in flow table.
PENDING_REMOVE - org.onosproject.net.meter.MeterState
The meter is in the process of being removed.
PENDING_UPDATE - org.onosproject.net.group.Group.GroupState
Group update request is processed by ONOS and not received the confirmation from data plane post which state moves to ADDED state.
pendingContexts() - Method in class org.onosproject.net.intent.IntentInstallationContext
Retrieves the pending contexts.
pendingFlowRule(FlowEntry) - Method in interface org.onosproject.net.flow.FlowRuleStore
Marks a flow rule as PENDING_ADD during retry.
pendingPackets() - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
pendingPackets() - Method in interface org.onosproject.net.packet.PacketInFilter
Get the current value of the count of packets for this particular filter type waiting to get processed.
performGroupOperation(DeviceId, GroupOperations) - Method in interface org.onosproject.net.group.GroupProgrammable
Performs the Group operations for the specified device.
performGroupOperation(DeviceId, GroupOperations) - Method in interface org.onosproject.net.group.GroupProvider
Performs a batch of group operation in the specified device with the specified parameters.
performMeterOperation(DeviceId, MeterOperation) - Method in interface org.onosproject.net.meter.MeterProvider
Performs a meter operation on the specified device with the specified parameters.
performMeterOperation(DeviceId, MeterOperations) - Method in interface org.onosproject.net.meter.MeterProvider
Performs a batch of meter operation on the specified device with the specified parameters.
performMeterOperation(MeterOperation) - Method in interface org.onosproject.net.meter.MeterProgrammable
Performs a meter operation on this device.
PERIODIC - org.onosproject.net.flow.StatTriggerFlag
Trigger for all multiples of thresholds.
permanent() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
permanent() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
permanent() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
permanent() - Method in interface org.onosproject.net.flowobjective.Objective
Whether this objective is permanent.
Permission - Class in org.onosproject.security
 
Permission(String, String) - Constructor for class org.onosproject.security.Permission
 
Permission(String, String, String) - Constructor for class org.onosproject.security.Permission
 
permissions() - Method in interface org.onosproject.app.ApplicationDescription
Returns the permissions requested by the application.
permissions() - Method in class org.onosproject.app.DefaultApplicationDescription
 
permissions() - Method in interface org.onosproject.core.Application
Returns the permissions requested by the application.
permissions() - Method in class org.onosproject.core.DefaultApplication
 
permit() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
permit() - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Permit this filtering condition set.
PERMIT - org.onosproject.net.flowobjective.FilteringObjective.Type
Permits packets that match the filtering condition to be processed by the rest of the pipeline.
perSec() - Method in class org.onosproject.ui.topo.TopoUtils.ValueLabel
Mark this value to be expressed as a rate.
PERSISTENCE_WRITE - org.onosproject.security.AppPermission.Type
 
PersistenceService - Interface in org.onosproject.persistence
Service that allows for the creation of local disk backed map for instance specific values that persist across restarts.
persistentMapBuilder() - Method in interface org.onosproject.persistence.PersistenceService
A builder for the creation of local persistent maps backed by disk.
PersistentMapBuilder<K,​V> - Interface in org.onosproject.persistence
The interface for a persistent map builder for use with mapDB.
persistentSetBuilder() - Method in interface org.onosproject.persistence.PersistenceService
A builder for the creation of local persistent sets backed by disk.
PersistentSetBuilder<E> - Interface in org.onosproject.persistence
The default interface for the persistent set builder for use with mapDB.
PiAction - Class in org.onosproject.net.pi.runtime
Instance of an action, and its runtime parameters, of a table entry in a protocol-independent pipeline.
PiAction.Builder - Class in org.onosproject.net.pi.runtime
Builder of protocol-independent actions.
PiActionId - Class in org.onosproject.net.pi.model
Identifier of an action of a match+action table in a protocol-independent pipeline, unique within the scope of a pipeline model.
PiActionModel - Interface in org.onosproject.net.pi.model
Model of an action with runtime parameters in a protocol-independent pipeline.
PiActionParam - Class in org.onosproject.net.pi.runtime
Instance of an action runtime parameter in a match+action table of a protocol-independent pipeline.
PiActionParam(PiActionParamId, byte) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and byte value.
PiActionParam(PiActionParamId, byte[]) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and byte array value.
PiActionParam(PiActionParamId, int) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and int value.
PiActionParam(PiActionParamId, long) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and long value.
PiActionParam(PiActionParamId, short) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and short value.
PiActionParam(PiActionParamId, String) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and string value.
PiActionParam(PiActionParamId, ImmutableByteSequence) - Constructor for class org.onosproject.net.pi.runtime.PiActionParam
Creates an action's runtime parameter for the given param ID and byte sequence value.
PiActionParamId - Class in org.onosproject.net.pi.model
Identifier of an action runtime parameter in a match+action table of a protocol-independent pipeline, unique within the scope an action model.
PiActionParamModel - Interface in org.onosproject.net.pi.model
Model of an action runtime parameter in a protocol-independent pipeline.
PiActionProfileGroup - Class in org.onosproject.net.pi.runtime
Instance of an action profile group of a protocol-independent pipeline.
PiActionProfileGroup.Builder - Class in org.onosproject.net.pi.runtime
Builder of action profile groups.
PiActionProfileGroup.WeightedMember - Class in org.onosproject.net.pi.runtime
Weighted reference to an action profile member as used in an action profile group.
PiActionProfileGroupHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI action profile group applied to a device, uniquely defined by a device ID, action profile ID and group ID.
PiActionProfileGroupId - Class in org.onosproject.net.pi.runtime
Identifier of an action profile group in a protocol-independent pipeline, unique within the scope of an action profile.
PiActionProfileId - Class in org.onosproject.net.pi.model
Identifier of an action profile in a protocol-independent pipeline, unique withing the scope of a pipeline model.
PiActionProfileMember - Class in org.onosproject.net.pi.runtime
Instance of a member of an action profile in a protocol-independent pipeline.
PiActionProfileMember.Builder - Class in org.onosproject.net.pi.runtime
Builder of action profile members.
PiActionProfileMemberHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI action profile member, uniquely defined by a device ID, action profile ID, and member ID.
PiActionProfileMemberId - Class in org.onosproject.net.pi.runtime
Identifier of a member of an action profile in a protocol-independent pipeline, unique within the scope on an action profile.
PiActionProfileModel - Interface in org.onosproject.net.pi.model
Model of an action profile in a protocol-independent pipeline.
PiActionSet - Class in org.onosproject.net.pi.runtime
Instance of an action set of a protocol-independent pipeline used when doing one-shot action selector programming.
PiActionSet.Builder - Class in org.onosproject.net.pi.runtime
Builder of an action set.
PiActionSet.WeightedAction - Class in org.onosproject.net.pi.runtime
Weighted action used in an actions set.
PiBitString - Class in org.onosproject.net.pi.runtime.data
BitString entity in a protocol-independent pipeline.
PiBool - Class in org.onosproject.net.pi.runtime.data
Boolean entity in a protocol-independent pipeline.
picky(Runnable, int) - Static method in class org.onlab.util.PredictableExecutor
Wraps the given Runnable into PredictableExecutor.PickyRunnable returning supplied hint.
picky(Runnable, Function<Runnable, Integer>) - Static method in class org.onlab.util.PredictableExecutor
Wraps the given Runnable into PredictableExecutor.PickyRunnable returning supplied hint.
picky(Callable<T>, int) - Static method in class org.onlab.util.PredictableExecutor
Wraps the given Callable into PredictableExecutor.PickyCallable returning supplied hint.
picky(Callable<T>, Function<Callable<T>, Integer>) - Static method in class org.onlab.util.PredictableExecutor
Wraps the given Callable into PredictableExecutor.PickyCallable returning supplied hint.
PickyFutureTask(Runnable, T) - Constructor for class org.onlab.util.PredictableExecutor.PickyFutureTask
PickyFutureTask(Callable<T>) - Constructor for class org.onlab.util.PredictableExecutor.PickyFutureTask
PiCloneSessionEntry - Class in org.onosproject.net.pi.runtime
Representation of a clone session entry of a protocol-independent packet replication engine (PRE).
PiCloneSessionEntry.Builder - Class in org.onosproject.net.pi.runtime
Builder of PI clone session entries.
PiCloneSessionEntryHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI clone session entry applied to the packet replication engine (PRE) of a device, uniquely defined by a device ID, and session ID.
PiCounterCell - Class in org.onosproject.net.pi.runtime
Counter cell of a protocol-independent pipeline.
PiCounterCell(PiCounterCellId, long, long) - Constructor for class org.onosproject.net.pi.runtime.PiCounterCell
Creates a new counter cell for the given cell identifier, number of packets and bytes.
PiCounterCell(PiCounterCellId, PiCounterCellData) - Constructor for class org.onosproject.net.pi.runtime.PiCounterCell
Creates a new counter cell for the given cell identifier and counter cell data.
PiCounterCellData - Class in org.onosproject.net.pi.runtime
Data of a counter cell of a protocol-independent pipeline.
PiCounterCellData(long, long) - Constructor for class org.onosproject.net.pi.runtime.PiCounterCellData
Creates a new counter cell data for the given number of packets and bytes.
PiCounterCellHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI counter cell instantiated on a device, uniquely defined by a device ID and cell ID.
PiCounterCellId - Class in org.onosproject.net.pi.runtime
Identifier of a counter cell in a protocol-independent pipeline.
PiCounterId - Class in org.onosproject.net.pi.model
Identifier of a counter in a protocol-independent pipeline, unique within the scope of a pipeline model.
PiCounterModel - Interface in org.onosproject.net.pi.model
Model of a counter in protocol-independent pipeline.
PiCounterModel.Unit - Enum in org.onosproject.net.pi.model
Counter unit.
PiCounterType - Enum in org.onosproject.net.pi.model
Type of counter in a protocol-independent pipeline.
PiCriterion - Class in org.onosproject.net.flow.criteria
Protocol-independent criterion.
PiCriterion.Builder - Class in org.onosproject.net.flow.criteria
PiCriterion Builder.
PiData - Interface in org.onosproject.net.pi.model
Representation of data that can be used for runtime operations of a protocol-independent pipeline.
PiData.Type - Enum in org.onosproject.net.pi.model
Types of data in a protocol-independent pipeline.
PiEntity - Interface in org.onosproject.net.pi.runtime
Abstraction of a runtime entity of a protocol-independent pipeline.
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
 
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
 
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiCounterCell
 
piEntityType() - Method in interface org.onosproject.net.pi.runtime.PiEntity
Returns the type of this entity.
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
 
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
 
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
 
piEntityType() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
 
PiEntityType - Enum in org.onosproject.net.pi.runtime
Type of runtime entity of a protocol-independent pipeline.
PiEnumString - Class in org.onosproject.net.pi.runtime.data
EnumString entity in a protocol-independent pipeline.
PiErrorString - Class in org.onosproject.net.pi.runtime.data
ErrorString entity in a protocol-independent pipeline.
PiExactFieldMatch - Class in org.onosproject.net.pi.runtime
Instance of an exact field match in a protocol-independent pipeline.
PiExactFieldMatch(PiMatchFieldId, ImmutableByteSequence) - Constructor for class org.onosproject.net.pi.runtime.PiExactFieldMatch
Creates an exact field match.
PiFieldMatch - Class in org.onosproject.net.pi.runtime
Instance of a field match in a protocol-independent pipeline.
PiFlowRuleTranslationStore - Interface in org.onosproject.net.pi.service
A PI translation store that keeps track of which flow rules have been translated to which PI table entries.
PiFlowRuleTranslator - Interface in org.onosproject.net.pi.service
A translator of flow rules to PI table entries.
PiGroupKey - Class in org.onosproject.net.pi.runtime
Implementation of GroupKey for the case of a protocol-independent pipeline.
PiGroupKey(PiTableId, PiActionProfileId, int) - Constructor for class org.onosproject.net.pi.runtime.PiGroupKey
Returns a new group key for the given table ID, action profile ID, and group ID.
PiGroupTranslationStore - Interface in org.onosproject.net.pi.service
A PI translation store that keeps track of which groups have been translated to which PI action profile groups.
PiGroupTranslator - Interface in org.onosproject.net.pi.service
A translator of groups to PI action profile groups.
PiHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI entity applied to a device, unique in the scope of the whole network.
PiHandle(DeviceId) - Constructor for class org.onosproject.net.pi.runtime.PiHandle
 
PiHeader - Class in org.onosproject.net.pi.runtime.data
Instance of a PiHeader in a protocol-independent pipeline.
PiHeaderStack - Class in org.onosproject.net.pi.runtime.data
Instance of a PiHeaderStack in a protocol-independent pipeline.
PiHeaderUnion - Class in org.onosproject.net.pi.runtime.data
PiHeaderUnion entity in a protocol-independent pipeline.
PiHeaderUnionStack - Class in org.onosproject.net.pi.runtime.data
PiHeaderUnionStack entity in a protocol-independent pipeline.
PiInstruction - Class in org.onosproject.net.flow.instructions
Representation of a protocol-independent instruction.
PiInterpreterException(String) - Constructor for exception org.onosproject.net.pi.model.PiPipelineInterpreter.PiInterpreterException
 
PiLpmFieldMatch - Class in org.onosproject.net.pi.runtime
Instance of a longest-prefix field match in a protocol-independent pipeline.
PiLpmFieldMatch(PiMatchFieldId, ImmutableByteSequence, int) - Constructor for class org.onosproject.net.pi.runtime.PiLpmFieldMatch
Creates a new LPM field match.
PIM - Class in org.onlab.packet
Implements PIM control packet format.
PIM - org.onosproject.net.mcast.McastRoute.Type
Deprecated.
Route originates from PIM.
PIM() - Constructor for class org.onlab.packet.PIM
Default constructor.
PIM_ADDRESS - Static variable in class org.onlab.packet.PIM
 
PIM_HEADER_LEN - Static variable in class org.onlab.packet.PIM
 
PIMAddrGroup - Class in org.onlab.packet.pim
 
PIMAddrGroup() - Constructor for class org.onlab.packet.pim.PIMAddrGroup
PIM Encoded Group Address.
PIMAddrGroup(String) - Constructor for class org.onlab.packet.pim.PIMAddrGroup
PIM Encoded Source Address.
PIMAddrGroup(IpPrefix) - Constructor for class org.onlab.packet.pim.PIMAddrGroup
PIM Encoded Group Address.
PIMAddrSource - Class in org.onlab.packet.pim
 
PIMAddrSource() - Constructor for class org.onlab.packet.pim.PIMAddrSource
PIM Encoded Group Address.
PIMAddrSource(String) - Constructor for class org.onlab.packet.pim.PIMAddrSource
PIM Encoded Source Address.
PIMAddrSource(IpPrefix) - Constructor for class org.onlab.packet.pim.PIMAddrSource
PIM Encoded Source Address.
PIMAddrUnicast - Class in org.onlab.packet.pim
 
PIMAddrUnicast() - Constructor for class org.onlab.packet.pim.PIMAddrUnicast
PIM Encoded Source Address.
PIMAddrUnicast(String) - Constructor for class org.onlab.packet.pim.PIMAddrUnicast
PIM Encoded Source Address.
PiMatchFieldId - Class in org.onosproject.net.pi.model
Identifier of a match field in a protocol-independent pipeline, unique within the scope of a table model.
PiMatchFieldModel - Interface in org.onosproject.net.pi.model
Model of a table match field in a protocol-independent pipeline.
PiMatchKey - Class in org.onosproject.net.pi.runtime
Representation of all field matches of an entry of a match+action table of a protocol-independent pipeline.
PiMatchKey.Builder - Class in org.onosproject.net.pi.runtime
Builder of match keys.
PiMatchType - Enum in org.onosproject.net.pi.model
Match types in a protocol-independent pipeline.
pimEnabled() - Method in class org.onosproject.routing.config.RouterConfig
Deprecated.
Returns whether PIM is enabled on this router.
PiMeterBand - Class in org.onosproject.net.pi.runtime
Represents a band used within a meter.
PiMeterBand(PiMeterBandType, long, long) - Constructor for class org.onosproject.net.pi.runtime.PiMeterBand
Creates a band with rate and burst.
PiMeterBandType - Enum in org.onosproject.net.pi.runtime
Type of meter band of a protocol-independent pipeline.
PiMeterCellConfig - Class in org.onosproject.net.pi.runtime
Configuration of a meter cell of a protocol-independent pipeline.
PiMeterCellConfig.Builder - Class in org.onosproject.net.pi.runtime
 
PiMeterCellHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI meter cell instantiated on a device, uniquely defined by a device ID and meter cell ID.
PiMeterCellId - Class in org.onosproject.net.pi.runtime
Identifier of a meter cell in a protocol-independent pipeline.
PiMeterId - Class in org.onosproject.net.pi.model
Identifier of a meter in a protocol-independent pipeline, unique within the scope of a pipeline model.
PiMeterModel - Interface in org.onosproject.net.pi.model
Model of a meter in a protocol-independent pipeline.
PiMeterModel.Unit - Enum in org.onosproject.net.pi.model
Meter rate unit.
PiMeterTranslationStore - Interface in org.onosproject.net.pi.service
A PI translation store that keeps track of which meters have been translated to which PI meters.
PiMeterTranslator - Interface in org.onosproject.net.pi.service
A translator of meters to PI Meter Configs.
PiMeterType - Enum in org.onosproject.net.pi.model
Types of meter in protocol-independent pipeline.
PIMHello - Class in org.onlab.packet.pim
 
PIMHello() - Constructor for class org.onlab.packet.pim.PIMHello
 
PIMHelloOption - Class in org.onlab.packet.pim
PIM HELLO option.
PIMHelloOption() - Constructor for class org.onlab.packet.pim.PIMHelloOption
Constructs a new hello option with no fields set.
PIMHelloOption(short) - Constructor for class org.onlab.packet.pim.PIMHelloOption
Set a PIM Hello option by type.
PIMJoinPrune - Class in org.onlab.packet.pim
 
PIMJoinPrune() - Constructor for class org.onlab.packet.pim.PIMJoinPrune
 
PIMJoinPruneGroup - Class in org.onlab.packet.pim
 
PIMJoinPruneGroup(IpPrefix) - Constructor for class org.onlab.packet.pim.PIMJoinPruneGroup
 
PiMulticastGroupEntry - Class in org.onosproject.net.pi.runtime
Representation of multicast group entry of a protocol-independent packet replication engine (PRE).
PiMulticastGroupEntry.Builder - Class in org.onosproject.net.pi.runtime
Builder of PI multicast group entries.
PiMulticastGroupEntryHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI multicast group entry applied to the packet replication engine of a device, uniquely defined by a device ID, and group ID.
PiOptionalFieldMatch - Class in org.onosproject.net.pi.runtime
Instance of an optional field match in a protocol-independent pipeline.
PiOptionalFieldMatch(PiMatchFieldId, ImmutableByteSequence) - Constructor for class org.onosproject.net.pi.runtime.PiOptionalFieldMatch
Creates an optional field match.
PiPacketMetadata - Class in org.onosproject.net.pi.runtime
Instance of a metadata field for a controller packet-in/out for a protocol-independent pipeline.
PiPacketMetadata.Builder - Class in org.onosproject.net.pi.runtime
Builder of protocol-independent packet metadatas.
PiPacketMetadataId - Class in org.onosproject.net.pi.model
Identifier of a packet metadata in a protocol-independent pipeline, unique within the scope of a pipeline model.
PiPacketMetadataModel - Interface in org.onosproject.net.pi.model
Model of a packet metadata for a protocol-independent pipeline.
PiPacketOperation - Class in org.onosproject.net.pi.runtime
Instance of a packet I/O operation that includes the packet body (frame) and its metadata, for a protocol-independent pipeline.
PiPacketOperation.Builder - Class in org.onosproject.net.pi.runtime
Builder of packet operations.
PiPacketOperationModel - Interface in org.onosproject.net.pi.model
Model of a packet operation in a protocol-independent pipeline.
PiPacketOperationType - Enum in org.onosproject.net.pi.model
Type of packet operation in a protocol-independent pipeline.
pipeconf() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device pipeconf.
pipeconf() - Method in class org.onosproject.net.pi.service.PiPipeconfEvent
Returns the pipeconf instance associated to this event, or null if one was not provided.
pipeconf(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device pipeconf.
PIPECONF_TABLE - Static variable in class org.onosproject.ui.GlyphConstants
 
PipeconfCommand - Class in org.onosproject.cli.net
Query registered pipeconfs.
PipeconfCommand() - Constructor for class org.onosproject.cli.net.PipeconfCommand
 
PIPELINE_INDEPENDENT - org.onosproject.net.flow.TableId.Type
Signifies that the table identifier is pipeline-independent.
PIPELINE_INDEPENDENT - org.onosproject.net.meter.MeterCellId.MeterCellType
Signifies that the meter cell identifier is pipeline-independent.
PIPELINE_READY - org.onosproject.net.pi.service.PiPipeconfWatchdogEvent.Type
 
PIPELINE_UNKNOWN - org.onosproject.net.pi.service.PiPipeconfWatchdogEvent.Type
 
pipelineModel() - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf
 
pipelineModel() - Method in interface org.onosproject.net.pi.model.PiPipeconf
Returns the pipeline model.
Pipeliner - Interface in org.onosproject.net.behaviour
Behaviour for handling various pipelines.
PipelinerContext - Interface in org.onosproject.net.behaviour
Processing context and supporting services for the pipeline behaviour.
PipelineTraceable - Interface in org.onosproject.net.behaviour
Represents a driver behavior that enables a logical packet to trace existing flows and groups in a device.
PipelineTraceableHitChain - Class in org.onosproject.net
Class to represent the pipeline hit chain and the result of the pipeline processing.
PipelineTraceableHitChain(ConnectPoint, List<DataPlaneEntity>, PipelineTraceablePacket) - Constructor for class org.onosproject.net.PipelineTraceableHitChain
Creates a new PipelineTraceableHitChain.
PipelineTraceableInput - Class in org.onosproject.net
Represents the input of the pipeline traceable processing.
PipelineTraceableInput(PipelineTraceablePacket, ConnectPoint, List<DataPlaneEntity>) - Constructor for class org.onosproject.net.PipelineTraceableInput
Builds a pipeline traceable input.
PipelineTraceableMetadata - Interface in org.onosproject.net
Stores traceable processing metadata.
PipelineTraceableOutput - Class in org.onosproject.net
Represents the output of the pipeline traceable processing.
PipelineTraceableOutput.Builder - Class in org.onosproject.net
Builder of pipeline traceable entities.
PipelineTraceableOutput.PipelineTraceableResult - Enum in org.onosproject.net
Represents the result of the pipeline traceable processing.
PipelineTraceablePacket - Class in org.onosproject.net
Represents a traceable packet composed by a traffic selector and metadata.
PipelineTraceablePacket(TrafficSelector) - Constructor for class org.onosproject.net.PipelineTraceablePacket
Builds a traceable packet without metadata.
PipelineTraceablePacket(TrafficSelector, PipelineTraceableMetadata) - Constructor for class org.onosproject.net.PipelineTraceablePacket
Builds a traceable packet with metadata.
PiPipeconf - Interface in org.onosproject.net.pi.model
Configuration of a protocol-independent pipeline that includes a pipeline model, a collection of pipeline-specific behaviour implementations, and extensions.
PiPipeconf.ExtensionType - Enum in org.onosproject.net.pi.model
Type of extension of a protocol-independent pipeline configuration.
PiPipeconfDeviceMappingEvent - Class in org.onosproject.net.pi.service
Entity that represents pipeconf to device binding events.
PiPipeconfDeviceMappingEvent(PiPipeconfDeviceMappingEvent.Type, DeviceId) - Constructor for class org.onosproject.net.pi.service.PiPipeconfDeviceMappingEvent
Creates an event due to one Pipeconf being mapped to a device.
PiPipeconfDeviceMappingEvent.Type - Enum in org.onosproject.net.pi.service
Type of pipeconf to device mapping event.
PiPipeconfEvent - Class in org.onosproject.net.pi.service
Event related to the PiPipeconfService.
PiPipeconfEvent(PiPipeconfEvent.Type, PiPipeconf) - Constructor for class org.onosproject.net.pi.service.PiPipeconfEvent
Creates anew pipeconf event for the given type and pipeconf.
PiPipeconfEvent(PiPipeconfEvent.Type, PiPipeconfId) - Constructor for class org.onosproject.net.pi.service.PiPipeconfEvent
Creates anew pipeconf event for the given type and pipeconf ID.
PiPipeconfEvent.Type - Enum in org.onosproject.net.pi.service
Type of pipeconf event.
PiPipeconfId - Class in org.onosproject.net.pi.model
An identifier of a protocol-independent pipeline configuration, unique within the scope of ONOS.
PiPipeconfId(String) - Constructor for class org.onosproject.net.pi.model.PiPipeconfId
Creates a pipeline configuration identifier.
PiPipeconfListener - Interface in org.onosproject.net.pi.service
Listener of pipeconf events.
PiPipeconfMappingStore - Interface in org.onosproject.net.pi.service
Manages the mapping of Pipeconfs that are deployed to devices; not intended for direct use.
PiPipeconfMappingStoreDelegate - Interface in org.onosproject.net.pi.service
Pipeconf store delegate abstraction.
piPipeconfService - Variable in class org.onosproject.cli.net.PipeconfCommand
 
PiPipeconfService - Interface in org.onosproject.net.pi.service
A service to manage the configurations of protocol-independent pipelines.
PiPipeconfWatchdogEvent - Class in org.onosproject.net.pi.service
Event representing changes in the status of a device pipeline.
PiPipeconfWatchdogEvent(PiPipeconfWatchdogEvent.Type, DeviceId) - Constructor for class org.onosproject.net.pi.service.PiPipeconfWatchdogEvent
Creates a new event for the given device.
PiPipeconfWatchdogEvent.Type - Enum in org.onosproject.net.pi.service
Type of event.
PiPipeconfWatchdogListener - Interface in org.onosproject.net.pi.service
Listener of pipeline status change events produced by PiPipeconfWatchdogService.
PiPipeconfWatchdogService - Interface in org.onosproject.net.pi.service
Service that periodically probes pipeline programmable devices, to check that their pipeline is configured with the expected pipeconf.
PiPipeconfWatchdogService.PipelineStatus - Enum in org.onosproject.net.pi.service
Status of a device pipeline.
PiPipelineInterpreter - Interface in org.onosproject.net.pi.model
An interpreter of a PI pipeline model.
PiPipelineInterpreter.PiInterpreterException - Exception in org.onosproject.net.pi.model
Signals that an error was encountered while executing the interpreter.
PiPipelineModel - Interface in org.onosproject.net.pi.model
Model of a protocol-independent pipeline.
PiPipelineProgrammable - Interface in org.onosproject.net.behaviour
Behavior to program the pipeline of a device that supports protocol-independence.
PiPreEntry - Interface in org.onosproject.net.pi.runtime
Configuration entry of a Packet Replication Engine (PRE) of protocol-independent pipeline.
PiPreEntryHandle - Class in org.onosproject.net.pi.runtime
Abstract implementation of a PI handle for PRE entries.
PiPreEntryType - Enum in org.onosproject.net.pi.runtime
Type of entry of the packet replication engine (PRE) or a protocol-independent pipeline.
PiPreReplica - Class in org.onosproject.net.pi.runtime
Representation of a packet replica used for multicast or cloning process in a protocol-independent packet replication engine.
PiPreReplica(PortNumber, int) - Constructor for class org.onosproject.net.pi.runtime.PiPreReplica
Returns a new PRE packet replica for the given egress port and instance ID.
pir() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the peak information rate (PIR) of this bandwidth profile.
pir(Bandwidth) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the peak information rate (PIR) of this builder.
PiRangeFieldMatch - Class in org.onosproject.net.pi.runtime
Instance of a range field match in a protocol-independent pipeline.
PiRangeFieldMatch(PiMatchFieldId, ImmutableByteSequence, ImmutableByteSequence) - Constructor for class org.onosproject.net.pi.runtime.PiRangeFieldMatch
Creates a new range field match for the given low and high value.
PiRegisterCell - Class in org.onosproject.net.pi.runtime
A register cell entry of a protocol-independent pipeline.
PiRegisterCell.Builder - Class in org.onosproject.net.pi.runtime
 
PiRegisterCellId - Class in org.onosproject.net.pi.runtime
Identifier of a register cell in a protocol-independent pipeline.
PiRegisterId - Class in org.onosproject.net.pi.model
Identifier of a register in a protocol-independent pipeline, unique within the scope of a pipeline model.
PiRegisterModel - Interface in org.onosproject.net.pi.model
Model of a register in a protocol-independent pipeline.
PiRegisterProgrammable - Interface in org.onosproject.net.behaviour
Protocol-independent register programmable device behaviour.
PiReplicationGroupTranslationStore - Interface in org.onosproject.net.pi.service
A PI translation store that keeps track of which groups have been translated to which PI packet replication engine (PRE) entry.
PiReplicationGroupTranslator - Interface in org.onosproject.net.pi.service
A translator of groups for packet replication to PI packet replication engine (PRE) entries.
PiStruct - Class in org.onosproject.net.pi.runtime.data
Struct entity in a protocol-independent pipeline.
piTableAction(PiTableAction) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
piTableAction(PiTableAction) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a protocol independent instruction.
piTableAction(PiTableAction) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the protocol independent table action.
PiTableAction - Interface in org.onosproject.net.pi.runtime
Instance of an action that can be executed as a consequence of a match in a match+action table of a protocol-independent pipeline.
PiTableAction.Type - Enum in org.onosproject.net.pi.runtime
Types of table action.
PiTableEntry - Class in org.onosproject.net.pi.runtime
Instance of a table entry in a protocol-independent pipeline.
PiTableEntry.Builder - Class in org.onosproject.net.pi.runtime
 
PiTableEntryHandle - Class in org.onosproject.net.pi.runtime
Global identifier of a PI table entry applied on a device, uniquely defined by a device ID, table ID and match key.
PiTableId - Class in org.onosproject.net.pi.model
Identifier of a table in a protocol-independent pipeline, unique within the scope of a pipeline model.
PiTableModel - Interface in org.onosproject.net.pi.model
Model of a match+action table in a protocol-independent pipeline.
PiTableType - Enum in org.onosproject.net.pi.model
Types of match+action table in a protocol-independent pipeline.
PiTernaryFieldMatch - Class in org.onosproject.net.pi.runtime
Instance of a ternary field match in a protocol-independent pipeline.
PiTernaryFieldMatch(PiMatchFieldId, ImmutableByteSequence, ImmutableByteSequence) - Constructor for class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
Creates a new ternary field match.
PiTranslatable - Interface in org.onosproject.net.pi.service
Abstraction of protocol-dependent (PD) entity that can be translated to an equivalent protocol-independent (PI) one.
PiTranslatedEntity<T extends PiTranslatable,​E extends PiEntity> - Class in org.onosproject.net.pi.service
Representation of the result of a PD-to-PI translation associated to a PI entity handle.
PiTranslatedEntity(T, E, PiHandle) - Constructor for class org.onosproject.net.pi.service.PiTranslatedEntity
Creates a new translated entity.
PiTranslationEvent<T extends PiTranslatable,​E extends PiEntity> - Class in org.onosproject.net.pi.service
Signals an event related to the translation of a protocol-dependent (PD) entity to a protocol-independent (PI) one.
PiTranslationEvent(PiTranslationEvent.Type, PiTranslatedEntity<T, E>) - Constructor for class org.onosproject.net.pi.service.PiTranslationEvent
Creates a new translation event.
PiTranslationEvent.Type - Enum in org.onosproject.net.pi.service
Type of event.
PiTranslationException - Exception in org.onosproject.net.pi.service
Signals that an error was encountered while translating an entity.
PiTranslationException(String) - Constructor for exception org.onosproject.net.pi.service.PiTranslationException
Creates a new exception with the given message.
PiTranslationService - Interface in org.onosproject.net.pi.service
A service to translate protocol-dependent (PD) entities to protocol-independent (PI) ones.
PiTranslationStore<T extends PiTranslatable,​E extends PiEntity> - Interface in org.onosproject.net.pi.service
PI translation store abstraction that maintains a mapping between a PI entity handle and a translated entity.
PiTranslationStoreDelegate<T extends PiTranslatable,​E extends PiEntity> - Interface in org.onosproject.net.pi.service
PI translation store delegate abstraction.
PiTranslator<T extends PiTranslatable,​E extends PiEntity> - Interface in org.onosproject.net.pi.service
A translator of PI entities to equivalent PD ones which offer means to learn translated entities for later use.
PiTuple - Class in org.onosproject.net.pi.runtime.data
Tuple entity in a protocol-independent pipeline.
PKT_TOO_BIG - org.onosproject.cli.net.Icmp6Type
Packet Too Big.
PKT_TOO_BIG - Static variable in class org.onlab.packet.ICMP6
Packet Too Big.
PKTS_PER_SEC - org.onosproject.net.behaviour.trafficcontrol.Policer.Unit
Packets per second.
PKTS_PER_SEC - org.onosproject.net.meter.Meter.Unit
Packets per second.
PlaceholderCompleter - Class in org.onosproject.cli
A completer that can be used as a placeholder for arguments that don't need/want completers.
PlaceholderCompleter() - Constructor for class org.onosproject.cli.PlaceholderCompleter
 
PLAIN_RX_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
PLAIN_TX_MASK - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
PLATFORM - org.onosproject.ui.UiView.Category
Represents platform related views.
PLAY - Static variable in class org.onosproject.ui.GlyphConstants
 
PLUS - Static variable in class org.onosproject.ui.GlyphConstants
 
PointToPointIntent - Class in org.onosproject.net.intent
Abstraction of point-to-point connectivity.
PointToPointIntent() - Constructor for class org.onosproject.net.intent.PointToPointIntent
Constructor for serializer.
PointToPointIntent.Builder - Class in org.onosproject.net.intent
Builder of a point to point intent.
Policer - Interface in org.onosproject.net.behaviour.trafficcontrol
Generic abstraction for a policer which can mark and/or discard ingress traffic.
Policer.Builder - Interface in org.onosproject.net.behaviour.trafficcontrol
A policer builder.
Policer.Unit - Enum in org.onosproject.net.behaviour.trafficcontrol
Unit of traffic used by this policer.
PolicerConfigurable - Interface in org.onosproject.net.behaviour.trafficcontrol
Behaviour for handling various drivers for policer configurations.
PolicerEntry - Interface in org.onosproject.net.behaviour.trafficcontrol
Represents a stored policer.
policerId() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
policerId() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
The id of this policer.
policerId() - Method in class org.onosproject.net.behaviour.trafficcontrol.PolicingResource
Return the policer id of this resource.
policerId(String) - Static method in class org.onosproject.net.behaviour.trafficcontrol.PolicerId
Creates a policer id using the supplied URI string.
policerId(URI) - Static method in class org.onosproject.net.behaviour.trafficcontrol.PolicerId
Creates a policer id using the supplied URI.
PolicerId - Class in org.onosproject.net.behaviour.trafficcontrol
Unique identifier for an ONOS Policer Policer.
PolicingResource - Class in org.onosproject.net.behaviour.trafficcontrol
Abstraction which encapsulates policer data to be used as network resource.
PolicingResource(PolicerId, ConnectPoint) - Constructor for class org.onosproject.net.behaviour.trafficcontrol.PolicingResource
 
poll() - Method in class org.onlab.util.UnmodifiableDeque
 
POLL_FREQUENCY - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
POLL_FREQUENCY_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
pollFirst() - Method in class org.onlab.util.UnmodifiableDeque
 
pollFirstEntry() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
pollFirstEntry() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return and remove the entry associated with the lowest key.
pollFirstEntry() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns and removes the entry associated with the lowest key.
PollInterval - Class in org.onosproject.net.statistic
Default polling interval values.
PollInterval() - Constructor for class org.onosproject.net.statistic.PollInterval
Creates an default poll interval.
pollLast() - Method in class org.onlab.util.UnmodifiableDeque
 
pollLastEntry() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
pollLastEntry() - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Return and remove the entry associated with the highest key.
pollLastEntry() - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns and removes the entry associated with the highest key.
pop() - Method in class org.onlab.util.UnmodifiableDeque
 
popMpls() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
popMpls() - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a pop MPLS header instruction.
popMpls() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Pops MPLS ether type.
popMpls(EthType) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
popMpls(EthType) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a pop MPLS header instruction with a particular ethertype.
popMpls(EthType) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Pops MPLS ether type and set the new ethertype.
populate(int) - Method in class org.onlab.util.KryoNamespace
Populates the Kryo pool.
populateChart(ChartModel, ObjectNode) - Method in class org.onosproject.ui.chart.ChartRequestHandler
Subclasses should populate the chart model by adding datapoints.
populateIPPoolfromRange(Ip4Address, Ip4Address) - Method in interface org.onosproject.dhcp.DhcpStore
Appends all the IPs in a given range to the free pool of IPs.
populateTable(TableModel, ObjectNode) - Method in class org.onosproject.ui.table.TableRequestHandler
Subclasses should populate the table model by adding rows.
popVlan() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
popVlan() - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a pop VLAN header instruction.
popVlan() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Pops outermost VLAN tag.
port() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
To return Port.
port() - Method in class org.onosproject.net.behaviour.ControllerInfo
Exposes the tcp port of the controller.
port() - Method in class org.onosproject.net.ConnectPoint
Returns the connection port number.
port() - Method in class org.onosproject.net.device.DeviceEvent
Returns the port subject.
port() - Method in class org.onosproject.net.flow.criteria.PortCriterion
Gets the input port number to match.
port() - Method in class org.onosproject.net.flow.instructions.Instructions.OutputInstruction
 
port() - Method in class org.onosproject.net.flow.instructions.Instructions.SetQueueInstruction
 
port() - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction.ModTransportPortInstruction
 
port() - Method in class org.onosproject.store.cluster.messaging.Endpoint
 
port() - Method in class org.onosproject.ui.model.topo.UiRegionDeviceLink
Returns the identity of the device port.
Port - Interface in org.onosproject.net
Abstraction of a network port.
PORT_ADDED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a port has been added.
PORT_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
PORT_DESERIALIZER_MAP - Static variable in class org.onlab.packet.UDP
 
PORT_IN - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the optical channel receiving/in port (RX).
PORT_MAC - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the port mac.
PORT_NAME - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the port name.
PORT_OFFSET - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
 
PORT_OUT - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the optical channel port transmitting/out port (TX).
PORT_REMOVED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a port has been removed.
PORT_STATS_UPDATED - org.onosproject.net.device.DeviceEvent.Type
Signifies that port statistics has been updated.
PORT_TABLE - Static variable in class org.onosproject.ui.GlyphConstants
 
PORT_TLV_COMPONENT_SUBTYPE - Static variable in class org.onlab.packet.LLDP
 
PORT_TLV_INTERFACE_NAME_SUBTYPE - Static variable in class org.onlab.packet.LLDP
 
PORT_TLV_SIZE - Static variable in class org.onlab.packet.LLDP
 
PORT_TLV_TYPE - Static variable in class org.onlab.packet.LLDP
 
PORT_UNREACH - org.onosproject.cli.net.Icmp6Code
Port unreachable.
PORT_UNREACH - Static variable in class org.onlab.packet.ICMP6
Port unreachable.
PORT_UPDATED - org.onosproject.net.device.DeviceEvent.Type
Signifies that a port has been updated.
Port.Type - Enum in org.onosproject.net
Represents coarse port type classification.
portA() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Returns the port number of device A.
portA() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the port of the first element.
PortAdmin - Interface in org.onosproject.net.behaviour
Means to administratively enable,disable and query the state of a port on a device.
PortAnnotationConfig - Class in org.onosproject.net.config.basics
Configuration to add extra annotations to a port via netcfg subsystem.
PortAnnotationConfig() - Constructor for class org.onosproject.net.config.basics.PortAnnotationConfig
Create a detached PortAnnotationConfig.
PortAnnotationConfig(ConnectPoint) - Constructor for class org.onosproject.net.config.basics.PortAnnotationConfig
Create a detached PortAnnotationConfig for specified port.
portB() - Method in class org.onosproject.ui.model.topo.UiDeviceLink
Returns the port number of device B.
portB() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the port of the second element.
PortConfigBehaviour - Interface in org.onosproject.net.behaviour
Means to configure a logical port at the device.
PortConfigOperator - Interface in org.onosproject.net.config
ConfigOperator for Port.
PortConfigOperatorRegistry - Interface in org.onosproject.net.config
Abstraction of a port operator registry.
PortCriterion - Class in org.onosproject.net.flow.criteria
Implementation of input port criterion.
PortDescription - Interface in org.onosproject.net.device
Information about a port.
portDescriptions() - Method in class org.onosproject.net.config.basics.PortDescriptionsConfig
Retrieves all port descriptions.
PortDescriptionsConfig - Class in org.onosproject.net.config.basics
Configuration for Ports.
PortDescriptionsConfig() - Constructor for class org.onosproject.net.config.basics.PortDescriptionsConfig
 
portId - Variable in class org.onlab.packet.LLDP
 
portNumber() - Method in class org.onosproject.net.device.DefaultPortDescription
 
portNumber() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
portNumber() - Method in interface org.onosproject.net.device.PortDescription
Returns the port number.
portNumber() - Method in interface org.onosproject.net.device.PortStatistics
Returns the port number.
portNumber() - Method in class org.onosproject.ui.model.topo.UiEdgeLink
Returns the edge port number.
portNumber(long) - Static method in class org.onosproject.net.PortNumber
Returns the port number representing the specified long value.
portNumber(long, String) - Static method in class org.onosproject.net.PortNumber
Returns the port number representing the specified long value and name.
portNumber(String) - Static method in class org.onosproject.net.PortNumber
Returns the port number representing the specified string value.
PortNumber - Class in org.onosproject.net
Representation of a port number.
PortNumber.Logical - Enum in org.onosproject.net
Logical PortNumbers.
PortNumberCompleter - Class in org.onosproject.cli.net
PortNumber completer, which returns candidates in PortNumber.toString() form.
PortNumberCompleter() - Constructor for class org.onosproject.cli.net.PortNumberCompleter
 
PortNumberSerializer - Class in org.onosproject.store.serializers
Serializer for PortNumber.
PortNumberSerializer() - Constructor for class org.onosproject.store.serializers.PortNumberSerializer
Creates PortNumber serializer instance.
PortQueryVlansCommand - Class in org.onosproject.cli.net
Command to show the list of unused vlan-ids.
PortQueryVlansCommand() - Constructor for class org.onosproject.cli.net.PortQueryVlansCommand
 
ports() - Method in class org.onosproject.net.config.inject.DeviceInjectionConfig
 
PORTS - Static variable in class org.onosproject.ui.GlyphConstants
 
PORTS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
portSpeed() - Method in class org.onosproject.net.DefaultPort
 
portSpeed() - Method in class org.onosproject.net.device.DefaultPortDescription
 
portSpeed() - Method in interface org.onosproject.net.device.PortDescription
Returns the current port speed in Mbps.
portSpeed() - Method in interface org.onosproject.net.Port
Returns the current port speed in Mbps.
portSpeed() - Method in class org.onosproject.net.utils.ForwardingPort
 
portSpeed(long) - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
Sets port speed.
PortStateCompleter - Class in org.onosproject.cli.net
PortState completer.
PortStateCompleter() - Constructor for class org.onosproject.cli.net.PortStateCompleter
 
PortStatistics - Interface in org.onosproject.net.device
Statistics of a port.
PortStatisticsDiscovery - Interface in org.onosproject.net.device
Handler behaviour capable of collecting and updating port statistics.
PortStatisticsService - Interface in org.onosproject.net.statistic
Service for obtaining statistic information about device ports.
PortStatisticsService.MetricType - Enum in org.onosproject.net.statistic
Specifies the type of metric.
portStatusChanged(DeviceId, PortDescription) - Method in interface org.onosproject.net.device.DeviceProviderService
Notifies the core about port status change of a single port.
PositionalParameterStringFormatter - Class in org.onlab.util
Allows slf4j style formatting of parameters into a string.
post(E) - Method in class org.onosproject.event.AbstractListenerManager
Safely posts the specified event to the local event dispatcher.
post(E) - Method in class org.onosproject.net.provider.AbstractListenerProviderRegistry
Safely posts the specified event to the local event dispatcher.
post(Event) - Method in interface org.onosproject.event.EventDispatcher
Posts the specified event for dispatching.
POSTCARD - org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable.IntFunctionality
Postcard functionality.
PowerConfig<T> - Interface in org.onosproject.net.behaviour
Behavior for handling port power configurations.
PowerConfigCommand - Class in org.onosproject.cli.net
Get the target-output-power for specific optical-channel.
PowerConfigCommand() - Constructor for class org.onosproject.cli.net.PowerConfigCommand
 
PPPoE - org.onosproject.net.behaviour.BngProgrammable.Attachment.AttachmentType
PPPoE attachment.
PPPoED - Class in org.onlab.packet
 
PPPoED - org.onlab.packet.EthType.EtherType
 
PPPoED() - Constructor for class org.onlab.packet.PPPoED
 
PPPOED_CODE_PADI - Static variable in class org.onlab.packet.PPPoED
 
PPPOED_CODE_PADO - Static variable in class org.onlab.packet.PPPoED
 
PPPOED_CODE_PADR - Static variable in class org.onlab.packet.PPPoED
 
PPPOED_CODE_PADS - Static variable in class org.onlab.packet.PPPoED
 
PPPOED_CODE_PADT - Static variable in class org.onlab.packet.PPPoED
 
PPPOED_TAG_AC_COOKIE - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_AC_NAME - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_AC_SYSTEM_ERROR - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_END_OF_LIST - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_GENERIC_ERROR - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_HOST_UNIQ - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_RELAY_SESSION_ID - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_SERVICE_NAME - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_SERVICE_NAME_ERROR - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPOED_TAG_VENDOR_SPECIFIC - Static variable in class org.onlab.packet.PPPoEDTag
 
PPPoED.Type - Enum in org.onlab.packet
 
PPPoEDTag - Class in org.onlab.packet
 
PPPoEDTag() - Constructor for class org.onlab.packet.PPPoEDTag
Default constructor.
PPPoEDTag(short, short, byte[]) - Constructor for class org.onlab.packet.PPPoEDTag
Constructs a PPPoED tag with type, length and value.
pppoeSessionId() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
Returns the PPPoE session ID of the attachment.
PRE_ENTRY - org.onosproject.net.pi.runtime.PiEntityType
Packet Replication Engine (PRE) entry.
PredictableExecutor - Class in org.onlab.util
(Somewhat) predictable ExecutorService.
PredictableExecutor(int, ThreadFactory) - Constructor for class org.onlab.util.PredictableExecutor
Creates PredictableExecutor instance.
PredictableExecutor(int, ThreadFactory, boolean) - Constructor for class org.onlab.util.PredictableExecutor
Creates PredictableExecutor instance.
PredictableExecutor(ThreadFactory) - Constructor for class org.onlab.util.PredictableExecutor
Creates PredictableExecutor instance with bucket size set to number of available processors.
PredictableExecutor.PickyCallable<T> - Interface in org.onlab.util
PredictableExecutor.PickyFutureTask<T> - Class in org.onlab.util
PredictableExecutor.PickyRunnable - Interface in org.onlab.util
PredictableExecutor.PickyTask - Interface in org.onlab.util
Abstraction to give a task a way to express it's preference to run on certain thread.
preEntryType() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
preEntryType() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
 
preEntryType() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
 
preEntryType() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
 
preEntryType() - Method in interface org.onosproject.net.pi.runtime.PiPreEntry
Returns the type of this PRE entry.
preEntryType() - Method in class org.onosproject.net.pi.runtime.PiPreEntryHandle
Returns the type of PRE entry associated with this handle.
PREFERENCE - org.onlab.packet.DHCP6.OptionCode
 
prefix - Variable in class org.onlab.packet.RIPngEntry
 
prefix() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
Get the IP prefix of this interface.
prefixLen - Variable in class org.onlab.packet.RIPngEntry
 
prefixLength() - Method in class org.onlab.packet.IpPrefix
Returns the IP address prefix length.
prefixLength() - Method in class org.onosproject.net.pi.runtime.PiLpmFieldMatch
Returns the prefix length to be matched.
prefixOnes(int, long) - Static method in class org.onlab.util.ImmutableByteSequence
Creates a new byte sequence that is prefixed with specified number of ones.
prefixZeros(int, long) - Static method in class org.onlab.util.ImmutableByteSequence
Creates a new byte sequence that is prefixed with specified number of zeros.
prepare(TransactionLog<T>) - Method in interface org.onosproject.store.service.Transactional
Prepares a transaction for commitment.
prepareAndCommit(TransactionLog<T>) - Method in interface org.onosproject.store.service.Transactional
Prepares and commits a transaction.
prepareForStatistics(FlowRule) - Method in interface org.onosproject.net.statistic.StatisticStore
Lay the foundation for receiving flow stats for this rule.
preProcess(PacketContext) - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
preProcess(PacketContext) - Method in interface org.onosproject.net.packet.PacketInFilter
Returns FilterAction before processing the packet.
preSetProperty(String, String, String) - Method in interface org.onosproject.cfg.ComponentConfigService
Presets the value of the specified configuration property, regardless of the component's state.
preSetProperty(String, String, String, boolean) - Method in interface org.onosproject.cfg.ComponentConfigService
Presets the value of the specified configuration property, regardless of the component's state.
prettifyXml(CharSequence) - Static method in class org.onlab.util.XmlString
Prettifies given XML String.
PrettyJson - Class in org.onosproject.cli
Pretty print previous command output JSON.
PrettyJson() - Constructor for class org.onosproject.cli.PrettyJson
 
PrettyXml - Class in org.onosproject.cli
Pretty print previous command output XML.
PrettyXml() - Constructor for class org.onosproject.cli.PrettyXml
 
PREV - Static variable in class org.onosproject.ui.GlyphConstants
 
prevConfig() - Method in class org.onosproject.net.config.NetworkConfigEvent
Returns previous config.
prevSubject() - Method in class org.onosproject.net.host.HostEvent
Gets the previous subject in this host event.
prevSubject() - Method in class org.onosproject.net.host.HostProbingEvent
Gets the previous subject in this host probe event.
prevSubject() - Method in class org.onosproject.net.intf.InterfaceEvent
Returns the previous interface subject.
prevSubject() - Method in class org.onosproject.net.mcast.McastEvent
Deprecated.
Gets the previous subject in this mcast event.
primary() - Method in class org.onlab.graph.DisjointPathPair
Returns the primary path.
primary() - Method in class org.onosproject.net.DefaultDisjointPath
 
primary() - Method in interface org.onosproject.net.DisjointPath
Gets primary path.
PRIMARY - org.onosproject.net.intent.PathIntent.ProtectionType
Intent within primary path.
PRIMARY_HIGHLIGHT - org.onosproject.ui.topo.LinkHighlight.Flavor
 
PrimitiveService - Interface in org.onosproject.store.service
Primitive service.
primitiveType() - Method in interface org.onosproject.store.service.AsyncAtomicCounter
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncAtomicIdGenerator
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncAtomicValue
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncConsistentMap
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncDistributedLock
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncDistributedSet
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncDocumentTree
 
primitiveType() - Method in interface org.onosproject.store.service.AsyncLeaderElector
 
primitiveType() - Method in interface org.onosproject.store.service.AtomicCounter
 
primitiveType() - Method in interface org.onosproject.store.service.AtomicCounterMap
 
primitiveType() - Method in interface org.onosproject.store.service.AtomicIdGenerator
 
primitiveType() - Method in interface org.onosproject.store.service.AtomicValue
 
primitiveType() - Method in interface org.onosproject.store.service.DistributedLock
 
primitiveType() - Method in interface org.onosproject.store.service.DistributedPrimitive
Returns the type of primitive.
primitiveType() - Method in interface org.onosproject.store.service.DocumentTree
 
primitiveType() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
 
primitiveType() - Method in interface org.onosproject.store.service.LeaderElector
 
primitiveType() - Method in class org.onosproject.store.service.Synchronous
 
primitiveType() - Method in interface org.onosproject.store.service.TransactionContext
 
primitiveType() - Method in interface org.onosproject.store.service.WorkQueue
 
print(String) - Static method in class org.onlab.junit.TestTools
 
print(String, Object...) - Method in class org.onosproject.cli.AbstractShellCommand
Prints the arguments using the specified format.
printDevice(DeviceService, Device) - Method in class org.onosproject.cli.net.DevicesListCommand
Prints information about the specified device.
printFlows(Device, List<FlowEntry>, CoreService) - Method in class org.onosproject.cli.net.FlowsListCommand
Prints flows.
printHost(Host) - Method in class org.onosproject.cli.net.HostsListCommand
Prints information about a host.
printPorts(DeviceService, Device) - Method in class org.onosproject.cli.net.DevicePortsListCommand
 
printRoles(MastershipService, DeviceId) - Method in class org.onosproject.cli.RolesCommand
Prints the role information for a device.
printTableStats(Device, List<TableStatisticsEntry>) - Method in class org.onosproject.cli.net.TableStatisticsCommand
Prints flow table statistics.
priority - Variable in class org.onosproject.net.intent.Intent.Builder
 
priority() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
Gets the priority to use for the intent.
priority() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
priority() - Method in interface org.onosproject.net.behaviour.QueueDescription
Returns priority, Valid only in specific type.
priority() - Method in class org.onosproject.net.flow.criteria.VlanPcpCriterion
Gets the VLAN priority to match.
priority() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
priority() - Method in interface org.onosproject.net.flow.FlowRule
Returns the flow rule priority given in natural order; higher numbers mean higher priorities.
priority() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
priority() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
priority() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
priority() - Method in interface org.onosproject.net.flowobjective.Objective
The priority for this objective.
priority() - Method in class org.onosproject.net.intent.Intent
Returns the priority of the intent.
priority() - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
priority() - Method in interface org.onosproject.net.packet.PacketProcessorEntry
Returns the packet processor priority.
priority() - Method in interface org.onosproject.net.packet.PacketRequest
Obtains the priority.
priority() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
Returns the priority of this table entry, if present.
priority() - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
Returns the optional priority associated with this handle.
priority(int) - Method in class org.onosproject.net.domain.DomainIntent.Builder
 
priority(int) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.ConnectivityIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.Intent.Builder
Sets the priority for the intent that will be built.
priority(int) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.PathIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
 
priority(int) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
 
priority(Long) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
 
priority(Long) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
Returns queue description builder with a given priority.
PRIORITY - org.onlab.packet.IPPrecedence
 
PRIORITY - org.onosproject.net.behaviour.QueueDescription.Type
Support priority.
PRIORITY_LENGTH - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
priorityCode - Variable in class org.onlab.packet.Ethernet
 
priorityValue() - Method in enum org.onosproject.net.packet.PacketPriority
Returns the integer value of the priority level.
PROBE_COMPLETED - org.onosproject.net.host.HostProbingEvent.Type
Probe has been complete normally.
PROBE_FAIL - org.onosproject.net.host.HostProbingEvent.Type
Probe timed out and reach max retry.
PROBE_REQUESTED - org.onosproject.net.host.HostProbingEvent.Type
Probe has been requested.
PROBE_TIMEOUT - org.onosproject.net.host.HostProbingEvent.Type
Probe timed out but still have not reach max retry.
probeAvailability() - Method in interface org.onosproject.net.device.DeviceHandshaker
Similar to DeviceHandshaker.isAvailable() but allows probing the device over the network.
ProbedLinkProvider - Interface in org.onosproject.net.link
Abstraction for an entity that provides information about infrastructure links that are discovered or verified using probe messages.
probeHost(Host, ConnectPoint, ProbeMode) - Method in interface org.onosproject.net.host.HostProbingProvider
Probe given host on the given connectPoint with given probeMode.
probeHost(Host, ConnectPoint, ProbeMode) - Method in interface org.onosproject.net.host.HostProbingService
Probes given host on given location.
probeMac() - Method in interface org.onosproject.net.host.HostProbe
Gets probe MAC of this entry.
ProbeMode - Enum in org.onosproject.net.host
Mode of host location probing.
probeReachability() - Method in interface org.onosproject.net.device.DeviceHandshaker
Similar to DeviceHandshaker.isReachable(), but performs probing of the device over the network.
process(ObjectNode) - Method in class org.onosproject.ui.chart.ChartRequestHandler
 
process(ObjectNode) - Method in class org.onosproject.ui.RequestHandler
Processes the incoming message payload from the client.
process(ObjectNode) - Method in class org.onosproject.ui.table.TableRequestHandler
 
process(ObjectNode) - Method in class org.onosproject.ui.UiMessageHandler
Processes a JSON message from the user interface client.
process(E) - Method in interface org.onosproject.event.EventSink
Processes the specified event.
process(E) - Method in class org.onosproject.event.ListenerRegistry
 
process(IntentData) - Method in interface org.onosproject.net.intent.IntentStoreDelegate
Provides an intent data object that should be processed (compiled and installed) by this manager.
process(PacketContext) - Method in interface org.onosproject.net.packet.PacketProcessor
Processes the inbound packet as specified in the given context.
processedBytes() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
processedBytes() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
processedBytes() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
Stats which reports how many bytes have been processed so far.
processedBytes() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Stats which reports how many bytes have been processed so far.
processedPackets() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
processedPackets() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
processedPackets() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
Stats which reports how many packets have been processed so far.
processedPackets() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Stats which reports how many packets have been processed so far.
processEvent(HostProbingEvent) - Method in interface org.onosproject.net.host.HostProbingProvider
Process host probing events.
processItems(List<T>) - Method in interface org.onlab.util.Accumulator
Processes the specified list of accumulated items.
processor() - Method in interface org.onosproject.net.packet.PacketProcessorEntry
Returns the packet processor.
processPacket(PacketContext) - Method in interface org.onosproject.net.packet.PacketProviderService
Submits inbound packet context for processing.
project(Class<B>) - Method in interface org.onosproject.net.driver.Projectable
Returns the specified projection of this entity if such projection is supported.
Projectable - Interface in org.onosproject.net.driver
Abstraction of an entity capable of being projected as another entity.
promote(String, NodeId) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
promote(String, NodeId) - Method in interface org.onosproject.store.service.AsyncLeaderElector
Attempts to promote a node to top of candidate list without displacing the current leader.
promote(String, NodeId) - Method in interface org.onosproject.store.service.LeaderElector
Attempts to promote a node to top of candidate list.
promoteToTopOfCandidateList(String, NodeId) - Method in interface org.onosproject.cluster.LeadershipAdminService
Make a node to be the next leader by promoting it to top of candidate list.
Prop(String, String, String) - Constructor for class org.onosproject.ui.topo.PropertyPanel.Prop
Constructs a property data value.
PROPAGATE - org.onosproject.store.service.RevisionType
A distributed primitive that is initialized from the state of the previous revision and to which changes to the previous revision are propagated.
properties() - Method in class org.onosproject.net.driver.DefaultDriver
 
properties() - Method in interface org.onosproject.net.driver.Driver
Returns the set of annotations as map of key/value properties.
properties() - Method in class org.onosproject.ui.topo.PropertyPanel
Returns the list of properties to be displayed.
Properties() - Constructor for class org.onosproject.ui.topo.TopoConstants.Properties
 
PROPERTY_SET - org.onosproject.cfg.ComponentConfigEvent.Type
Signifies that a configuration property has set.
PROPERTY_UNSET - org.onosproject.cfg.ComponentConfigEvent.Type
Signifies that a configuration property has been unset.
PropertyPanel - Class in org.onosproject.ui.topo
Models a panel displayed on the Topology View.
PropertyPanel(String, String) - Constructor for class org.onosproject.ui.topo.PropertyPanel
Constructs a property panel model with the given title and glyph identifier (icon to display).
PropertyPanel.Prop - Class in org.onosproject.ui.topo
Simple data carrier for a property, composed of a key/label/value trio.
PROTECTED - Static variable in class org.onosproject.net.AnnotationKeys
Link annotation key to express that a Link is backed by underlying protection mechanism.
ProtectedConstraint - Class in org.onosproject.net.intent.constraint
Constraint to request using only protected Links.
ProtectedConstraint() - Constructor for class org.onosproject.net.intent.constraint.ProtectedConstraint
 
ProtectedTransportEndpointDescription - Class in org.onosproject.net.behaviour.protection
Configuration for a protected transport entity endpoint.
ProtectedTransportEndpointDescription(List<TransportEndpointDescription>, DeviceId, String) - Constructor for class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
Constructor.
ProtectedTransportEndpointState - Class in org.onosproject.net.behaviour.protection
State of protected path endpoint.
ProtectedTransportEndpointState(ProtectedTransportEndpointDescription, List<TransportEndpointState>, int) - Constructor for class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
 
ProtectedTransportEndpointState.Builder - Class in org.onosproject.net.behaviour.protection
 
ProtectedTransportIntent - Class in org.onosproject.net.intent
Intent to create a protected linear path.
ProtectedTransportIntent.Builder - Class in org.onosproject.net.intent
protection() - Static method in class org.onosproject.net.intent.constraint.ProtectionConstraint
Returns protection constraint.
ProtectionConfig - Class in org.onosproject.net.behaviour.protection
Config object for protection end-point.
ProtectionConfig() - Constructor for class org.onosproject.net.behaviour.protection.ProtectionConfig
ProtectionConfig(DeviceId) - Constructor for class org.onosproject.net.behaviour.protection.ProtectionConfig
Create a ProtectionConfig for specified Device.
ProtectionConfigBehaviour - Interface in org.onosproject.net.behaviour.protection
Behaviour for configuring Device triggered protection mechanism.
ProtectionConstraint - Class in org.onosproject.net.intent.constraint
Constraint that determines whether to employ path protection.
ProtectionConstraint() - Constructor for class org.onosproject.net.intent.constraint.ProtectionConstraint
 
ProtectionEndpointIntent - Class in org.onosproject.net.intent
Installable Intent for the ProtectionEndpoint (head/tail).
ProtectionEndpointIntent(ApplicationId, Key, Collection<NetworkResource>, int, DeviceId, ProtectedTransportEndpointDescription, ResourceGroup) - Constructor for class org.onosproject.net.intent.ProtectionEndpointIntent
Creates a ProtectionEndpointIntent by specific resource and description.
ProtectionEndpointIntent.Builder - Class in org.onosproject.net.intent
ProtectionException - Exception in org.onosproject.net.behaviour.protection
Base class for Protection related Exceptions.
ProtectionException() - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException
Default constructor.
ProtectionException(String) - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException
Creates an exception.
ProtectionException(String, Throwable) - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException
Creates an exception.
ProtectionException(Throwable) - Constructor for exception org.onosproject.net.behaviour.protection.ProtectionException
Creates an exception.
ProtectionException.InvalidConfigException - Exception in org.onosproject.net.behaviour.protection
Exception thrown when specified configuration was invalid.
PROTO_TYPE_IP - Static variable in class org.onlab.packet.ARP
 
protocol - Variable in class org.onlab.packet.IPv4
 
protocol - Variable in class org.onlab.packet.MPLS
 
protocol() - Method in class org.onosproject.net.flow.criteria.IPProtocolCriterion
Gets the IP protocol to match.
protocol() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the protocol of the packet.
PROTOCOL - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for southbound protocol.
PROTOCOL - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
PROTOCOL_AH - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_DESERIALIZER_MAP - Static variable in class org.onlab.packet.IPv4
 
PROTOCOL_DESERIALIZER_MAP - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_DESERIALIZER_MAP - Static variable in class org.onlab.packet.PIM
 
PROTOCOL_DESERIALIZER_MAP - Static variable in class org.onlab.packet.Slow
 
PROTOCOL_DSTOPT - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_ESP - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_FRAG - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_HOPOPT - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_ICMP - Static variable in class org.onlab.packet.IPv4
 
PROTOCOL_ICMP6 - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_IGMP - Static variable in class org.onlab.packet.IPv4
 
PROTOCOL_INDEPENDENT - org.onosproject.net.flow.criteria.Criterion.Type
Protocol-independent.
PROTOCOL_INDEPENDENT - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that a protocol-independent instruction will be used.
PROTOCOL_IPV4 - Static variable in class org.onlab.packet.MPLS
 
PROTOCOL_IPV6 - Static variable in class org.onlab.packet.MPLS
 
PROTOCOL_MPLS - Static variable in class org.onlab.packet.MPLS
 
PROTOCOL_PIM - Static variable in class org.onlab.packet.IPv4
 
PROTOCOL_ROUTING - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_TCP - Static variable in class org.onlab.packet.IPv4
 
PROTOCOL_TCP - Static variable in class org.onlab.packet.IPv6
 
PROTOCOL_UDP - Static variable in class org.onlab.packet.IPv4
 
PROTOCOL_UDP - Static variable in class org.onlab.packet.IPv6
 
protocolAddressLength - Variable in class org.onlab.packet.ARP
 
ProtocolException() - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException.ProtocolException
 
protocolType - Variable in class org.onlab.packet.ARP
 
Provided - Interface in org.onosproject.net
Abstraction of an entity supplied by a provider.
provider - Variable in class org.onosproject.rest.AbstractApiDocRegistrator
 
provider() - Method in class org.onosproject.net.provider.AbstractProviderService
 
provider() - Method in interface org.onosproject.net.provider.ProviderService
Returns the provider to which this service has been issued.
Provider - Interface in org.onosproject.net.provider
Abstraction of a provider of information about network environment.
providerId() - Method in class org.onosproject.cluster.ClusterMetadata
 
providerId() - Method in class org.onosproject.net.AbstractModel
 
providerId() - Method in interface org.onosproject.net.Provided
Returns the identifier of the provider which supplied the entity.
providerId() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
providerId(ProviderId) - Method in class org.onosproject.net.DefaultLink.Builder
Sets the providerId to be used by the builder.
ProviderId - Class in org.onosproject.net.provider
External identity of a Provider family.
ProviderId(String, String) - Constructor for class org.onosproject.net.provider.ProviderId
Creates a new primary provider identifier from the specified string.
ProviderId(String, String, boolean) - Constructor for class org.onosproject.net.provider.ProviderId
Creates a new provider identifier from the specified string.
ProviderIdSerializer - Class in org.onosproject.store.serializers
Serializer for ProviderId.
ProviderIdSerializer() - Constructor for class org.onosproject.store.serializers.ProviderIdSerializer
Creates ProviderId serializer instance.
providerRegistry - Variable in class org.onosproject.common.net.AbstractDeviceProvider
 
ProviderRegistry<P extends Provider,​S extends ProviderService<P>> - Interface in org.onosproject.net.provider
Registry for tracking information providers with the core.
providerService - Variable in class org.onosproject.common.net.AbstractDeviceProvider
 
ProviderService<P extends Provider> - Interface in org.onosproject.net.provider
Abstraction of a service through which providers can inject information about the network environment into the core.
ProxyArpStoreDelegate - Interface in org.onosproject.net.proxyarp
Proxy ARP store delegate.
ProxyFactory<T> - Interface in org.onosproject.cluster
Constructs proxy instances for nodes in the cluster.
ProxyService - Interface in org.onosproject.cluster
Manages remote proxy services and instances.
PRUNEDELAY_LENGTH - Static variable in class org.onlab.packet.pim.PIMHelloOption
 
PSH - org.onosproject.net.flow.criteria.Criterion.TcpFlags
Push the buffered data to the receiving application.
publish(T) - Method in interface org.onosproject.store.service.Topic
Publishes a message to all subscribers.
punt() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
punt() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Adds a punt-to-controller instruction.
purge(Intent) - Static method in class org.onosproject.net.intent.IntentData
Creates IntentData for Intent purge request.
purge(Intent) - Method in interface org.onosproject.net.intent.IntentService
Purges a specific intent from the system if it is FAILED or WITHDRAWN.
PURGE_ON_DISCONNECTION - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
PURGE_ON_DISCONNECTION_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
PURGE_REQ - org.onosproject.net.intent.IntentState
Indicates that the intent should be purged from the database.
purgeAll(ApplicationId) - Method in interface org.onosproject.net.behaviour.Pipeliner
Purges all objectives for the given application.
purgeAll(DeviceId, ApplicationId) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveService
Purges all flow objectives on a given device and for a given application.
purgeApplication(String) - Method in class org.onosproject.common.app.ApplicationArchive
Purges the application archive directory.
PURGED - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent has been purged from the system.
purgeFlowRule(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleStore
Removes all flow entries of given device from store.
purgeFlowRules() - Method in interface org.onosproject.net.flow.FlowRuleStore
Removes all flow entries from store.
purgeFlowRules(DeviceId) - Method in interface org.onosproject.net.flow.FlowRuleService
Purges all the flow rules on the specified device.
purgeFlowRules(DeviceId, ApplicationId) - Method in interface org.onosproject.net.flow.FlowRuleService
Purges all the flow rules on the specified device from the given application id.
purgeFlowRules(DeviceId, ApplicationId) - Method in interface org.onosproject.net.flow.FlowRuleStore
Removes all flow entries of given device and application ID from store.
purgeGroupEntries() - Method in interface org.onosproject.net.group.GroupService
Purges all group entries.
purgeGroupEntries() - Method in interface org.onosproject.net.group.GroupStore
Removes all group entries from store.
purgeGroupEntries(DeviceId) - Method in interface org.onosproject.net.group.GroupService
Purges all the group entries on the specified device.
purgeGroupEntries(DeviceId, ApplicationId) - Method in interface org.onosproject.net.group.GroupService
Purges all the group entries on the specified device and application.
purgeGroupEntries(DeviceId, ApplicationId) - Method in interface org.onosproject.net.group.GroupStore
Removes all group entries of given device and given application from store.
purgeGroupEntry(DeviceId) - Method in interface org.onosproject.net.group.GroupStore
Removes all group entries of given device from store.
purgeIntentsInteractive(Iterable<Intent>) - Method in class org.onosproject.cli.net.IntentRemoveCommand
Purges the intents passed as argument after confirmation is provided for each of them.
purgeMeter(Meter) - Method in interface org.onosproject.net.meter.MeterStore
Delete this meter immediately.
purgeMeters(DeviceId) - Method in interface org.onosproject.net.meter.MeterService
Purges all the meters on the specified device.
purgeMeters(DeviceId) - Method in interface org.onosproject.net.meter.MeterStore
Removes all meters of given device from store.
purgeMeters(DeviceId, ApplicationId) - Method in interface org.onosproject.net.meter.MeterService
Purges all the meters on the given device and for the given application.
purgeMeters(DeviceId, ApplicationId) - Method in interface org.onosproject.net.meter.MeterStore
Removes all meters of given device and for the given application from store.
purgeOnDisconnection() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device purgeOnDisconnection flag for this device.
purgeOnDisconnection(boolean) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the purgeOnDisconnection flag for the device.
purgeOnUninstall() - Method in class org.onosproject.store.service.ConsistentMapOptions
Returns if map entries need to be cleared when owning application is uninstalled.
purgeOnUninstall() - Method in class org.onosproject.store.service.ConsistentMultimapOptions
Returns if multimap entries need to be cleared when owning application is uninstalled.
purgeOnUninstall() - Method in class org.onosproject.store.service.ConsistentTreeMapOptions
Return if map entries need to be cleared when owning application is uninstalled.
purgeOnUninstall() - Method in class org.onosproject.store.service.DistributedSetOptions
Returns if set contents need to be cleared when owning application is uninstalled.
purgeOnUninstall() - Method in class org.onosproject.store.service.DocumentTreeOptions
Return if document tree entries need to be cleared when owning application is uninstalled.
push(E) - Method in class org.onlab.util.UnmodifiableDeque
 
pushFlowMetrics(DeviceId, Iterable<FlowEntry>) - Method in interface org.onosproject.net.flow.FlowRuleProviderService
Pushes the collection of flow entries currently applied on the given device.
pushFlowMetricsWithoutFlowMissing(DeviceId, Iterable<FlowEntry>) - Method in interface org.onosproject.net.flow.FlowRuleProviderService
Pushes the collection of flow entries currently applied on the given device without flowMissing process.
pushGroupMetrics(DeviceId, Collection<Group>) - Method in interface org.onosproject.net.group.GroupProviderService
Pushes the collection of group detected in the data plane along with statistics.
pushGroupMetrics(DeviceId, Collection<Group>) - Method in interface org.onosproject.net.group.GroupStore
Submits the group metrics to store for a given device ID.
pushMeterFeatures(DeviceId, Collection<MeterFeatures>) - Method in interface org.onosproject.net.meter.MeterProviderService
Pushes the collection of meter features collected from the device.
pushMeterFeatures(DeviceId, MeterFeatures) - Method in interface org.onosproject.net.meter.MeterProviderService
Pushes the meter features collected from the device.
pushMeterMetrics(DeviceId, Collection<Meter>) - Method in interface org.onosproject.net.meter.MeterProviderService
Pushes the collection of meters observed on the data plane as well as their associated statistics.
pushMpls() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
pushMpls() - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a push MPLS header instruction.
pushMpls() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Push MPLS ether type.
pushQfi() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Returns whether QFi should be pushed to the packet.
pushTableStatistics(DeviceId, List<TableStatisticsEntry>) - Method in interface org.onosproject.net.flow.FlowRuleProviderService
Pushes the collection of table statistics entries currently extracted from the given device.
pushVlan() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
pushVlan() - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a push VLAN header instruction.
pushVlan() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Pushes a new VLAN tag.
pushVlan(EthType) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
pushVlan(EthType) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a push VLAN header instruction using the supplied Ethernet type.
pushVlan(EthType) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Pushes a new VLAN tag using the supplied Ethernet type.
put(String, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
put(K, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
put(K, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Associates ewValue with key in this map, and returns the value previously associated with key, or zero if there was no such value.
put(K, long) - Method in interface org.onosproject.store.service.AtomicCounterMap
Associates ewValue with key in this map, and returns the value previously associated with key, or zero if there was no such value.
put(K, V) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
put(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
put(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
put(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Associates the specified value with the specified key in this map (optional operation).
put(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
If the key-value pair does not already exist adds either the key value pair or the value to the set of values associated with the key and returns true, if the key-value pair already exists then behavior is implementation specific with some implementations allowing duplicates and others ignoring put requests for existing entries.
put(K, V) - Method in interface org.onosproject.store.service.ConsistentMap
Associates the specified value with the specified key in this map (optional operation).
put(K, V) - Method in interface org.onosproject.store.service.ConsistentMultimap
If the key-value pair does not already exist adds either the key value pair or the value to the set of values associated with the key and returns true, if the key-value pair already exists then behavior is implementation specific with some implementations allowing duplicates and others ignoring put requests for existing entries.
put(K, V) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Associates the specified value to the specified key in this map.
put(K, V) - Method in interface org.onosproject.store.service.TransactionalMap
Associates the specified value with the specified key in this map (optional operation).
PUT - org.onosproject.store.service.EventuallyConsistentMapEvent.Type
Entry added to map or existing entry updated.
PUT_IF_VERSION_MATCH - org.onosproject.store.primitives.MapUpdate.Type
Updates an entry if the current version matches specified version.
putAll(Map<? extends K, ? extends V>) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
putAll(Map<? extends K, ? extends V>) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Adds mappings for all key-value pairs in the specified map to this map.
putAll(Map<String, String>) - Method in class org.onosproject.net.DefaultAnnotations.Builder
Adds all entries in specified map.
putAll(Map<K, Collection<? extends V>>) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
putAll(Map<K, Collection<? extends V>>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Adds the set of key-value pairs of the specified mapping with each of the values in the iterable if each key-value pair does not already exist, if the pair does exist the behavior is implementation specific.
putAll(Map<K, Collection<? extends V>>) - Method in interface org.onosproject.store.service.ConsistentMultimap
Adds the set of key-value pairs of the specified mapping with each of the values in the iterable if each key-value pair does not already exist, if the pair does exist the behavior is implementation specific.
putAll(K, Collection<? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
putAll(K, Collection<? extends V>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Adds the set of key-value pairs of the specified key with each of the values in the iterable if each key-value pair does not already exist, if the pair does exist the behavior is implementation specific.
putAll(K, Collection<? extends V>) - Method in interface org.onosproject.store.service.ConsistentMultimap
Adds the set of key-value pairs of the specified key with each of the values in the iterable if each key-value pair does not already exist, if the pair does exist the behavior is implementation specific.
putAll(Annotations) - Method in class org.onosproject.net.DefaultAnnotations.Builder
Adds all specified annotation.
putAndGet(String, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
putAndGet(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
putAndGet(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
putAndGet(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Associates the specified value with the specified key in this map (optional operation).
putAndGet(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
If the key-value pair does not already exist adds either the key value pair or the value to the set of values associated with the key and returns the updated value, if the key-value pair already exists then behavior is implementation specific with some implementations allowing duplicates and others ignoring put requests for existing entries.
putAndGet(K, V) - Method in interface org.onosproject.store.service.ConsistentMap
Associates the specified value with the specified key in this map (optional operation).
putAndGet(K, V) - Method in interface org.onosproject.store.service.ConsistentMultimap
If the key-value pair does not already exist adds either the key value pair or the value to the set of values associated with the key and returns the updated value, if the key-value pair already exists then behavior is implementation specific with some implementations allowing duplicates and others ignoring put requests for existing entries.
putIfAbsent(String, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
putIfAbsent(K, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
putIfAbsent(K, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
If key is not already associated with a value or if key is associated with zero, associate it with newValue.
putIfAbsent(K, long) - Method in interface org.onosproject.store.service.AtomicCounterMap
If key is not already associated with a value or if key is associated with zero, associate it with newValue.
putIfAbsent(K, V) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
putIfAbsent(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
putIfAbsent(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
If the specified key is not already associated with a value associates it with the given value and returns null, else behaves as a get returning the existing mapping without making any changes.
putIfAbsent(K, V) - Method in interface org.onosproject.store.service.ConsistentMap
If the specified key is not already associated with a value associates it with the given value and returns null, else returns the current value.
putIfAbsent(K, V) - Method in interface org.onosproject.store.service.TransactionalMap
If the specified key is not already associated with a value associates it with the given value and returns null, else returns the current value.
putNextGroup(Integer, NextGroup) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveStore
Adds a NextGroup to the store, by mapping it to the nextId as key, and replacing any previous mapping.
PWM_PROBE_INTERVAL - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
PWM_PROBE_INTERVAL_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 

Q

qfi() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Get the QoS Flow Identifier for this PDR.
QINQ - org.onlab.packet.EthType.EtherType
 
qInQPriorityCode - Variable in class org.onlab.packet.Ethernet
 
qinqTPID - Variable in class org.onlab.packet.Ethernet
 
qinqVID - Variable in class org.onlab.packet.Ethernet
 
QosConfigBehaviour - Interface in org.onosproject.net.behaviour
Behaviour for handling various operations for qos configurations.
QosDescription - Interface in org.onosproject.net.behaviour
Default implementation of immutable Qos description.
QosDescription.Builder - Interface in org.onosproject.net.behaviour
Builder of qos description entities.
QosDescription.Type - Enum in org.onosproject.net.behaviour
Denotes the type of the Qos.
qosId() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
qosId() - Method in interface org.onosproject.net.behaviour.QosDescription
Returns qos identifier.
qosId(String) - Static method in class org.onosproject.net.behaviour.QosId
 
qosId(QosId) - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
 
qosId(QosId) - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
Returns qos description builder with a given name.
QosId - Class in org.onosproject.net.behaviour
Immutable representation of a Qos identity.
QUERY - Static variable in class org.onosproject.ui.GlyphConstants
 
QUERY - Static variable in class org.onosproject.ui.table.cell.AbstractCellFormatter
 
queryLambdas(PortNumber) - Method in interface org.onosproject.net.behaviour.LambdaQuery
Returns set of OchSignal instances which can be used at the port.
queryMplsLabels(PortNumber) - Method in interface org.onosproject.net.behaviour.MplsQuery
Returns set of MplsLabels which can be used at the port.
queryTributarySlots(PortNumber) - Method in interface org.onosproject.net.behaviour.TributarySlotQuery
Returns set of TributarySlot instances which can be used at the port.
queryType - Variable in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
queryVlanIds(PortNumber) - Method in interface org.onosproject.net.behaviour.VlanQuery
Returns set of VlanIds which can be used at the port.
QUEUE - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be enqueued to an already-configured queue on a port.
QUEUE_OCCUPANCY - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
The build-up of traffic in the queue that the INT packet observes in the device while being forwarded.
queueConfig(S, String, JsonNode) - Method in interface org.onosproject.net.config.NetworkConfigStore
Queues pending configuration for the specified subject and configuration class using the raw JSON object.
QueueConfigBehaviour - Interface in org.onosproject.net.behaviour
Behaviour for handling various operations for queue configurations.
QueueDescription - Interface in org.onosproject.net.behaviour
Default implementation of immutable Queue description.
QueueDescription.Builder - Interface in org.onosproject.net.behaviour
 
QueueDescription.Type - Enum in org.onosproject.net.behaviour
Denotes the type of the Queue.
queueId() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
queueId() - Method in interface org.onosproject.net.behaviour.QueueDescription
Returns queue identifier.
queueId() - Method in class org.onosproject.net.flow.instructions.Instructions.SetQueueInstruction
 
queueId(String) - Static method in class org.onosproject.net.behaviour.QueueId
 
queueId(QueueId) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
 
queueId(QueueId) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
Returns queue description builder with given name.
QueueId - Class in org.onosproject.net.behaviour
Immutable representation of a Queue identity.
queues() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
queues() - Method in interface org.onosproject.net.behaviour.QosDescription
Returns map of integer-Queue pairs, Valid only in specific qos type.
queues(Map<Long, QueueDescription>) - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
 
queues(Map<Long, QueueDescription>) - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
Returns qos description builder with a given queues.
QueuesListCommand - Class in org.onosproject.cli.net
Command to list stats for all work queues in the system.
QueuesListCommand() - Constructor for class org.onosproject.cli.net.QueuesListCommand
 

R

RACK - org.onosproject.net.region.Region.Type
Region represents a rack.
RACK_ADDRESS - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for device location.
RACK_ADDRESS - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for rack address.
rackAddress() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns the element rack address.
rackAddress(String) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets element rack address.
RADIUS - Class in org.onlab.packet
RADIUS packet.
RADIUS - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
RADIUS() - Constructor for class org.onlab.packet.RADIUS
Default constructor.
RADIUS(byte, byte) - Constructor for class org.onlab.packet.RADIUS
Constructs a RADIUS packet with the given code and identifier.
RADIUS_ATTR_ACCT_SESSION_ID - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_CALLING_STATION_ID - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_EAP_MESSAGE - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_FRAMED_MTU - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_MESSAGE_AUTH - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_NAS_ID - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_NAS_IP - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_NAS_PORT - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_NAS_PORT_ID - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_NAS_PORT_TYPE - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_STATE - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_USERNAME - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_ATTR_VENDOR_SPECIFIC - Static variable in class org.onlab.packet.RADIUSAttribute
 
RADIUS_CODE_ACCESS_ACCEPT - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_CODE_ACCESS_CHALLENGE - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_CODE_ACCESS_REJECT - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_CODE_ACCESS_REQUEST - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_CODE_ACCOUNTING_REQUEST - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_CODE_ACCOUNTING_RESPONSE - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_MAX_LENGTH - Static variable in class org.onlab.packet.RADIUS
 
RADIUS_MIN_LENGTH - Static variable in class org.onlab.packet.RADIUS
 
RADIUSAttribute - Class in org.onlab.packet
An attribute in a RADIUS packet.
RADIUSAttribute() - Constructor for class org.onlab.packet.RADIUSAttribute
Default constructor.
RADIUSAttribute(byte, byte, byte[]) - Constructor for class org.onlab.packet.RADIUSAttribute
Constructs a RADIUS attribute with the give type, length and value.
randomDelay(int) - Static method in class org.onlab.util.Tools
Suspends the current thread for a random number of millis between 0 and the indicated limit.
RandomIntentCommand - Class in org.onosproject.cli.net
Installs bulk host-to-host intents between hosts of the network.
RandomIntentCommand() - Constructor for class org.onosproject.cli.net.RandomIntentCommand
 
RANGE - org.onosproject.net.pi.model.PiMatchType
Range match type.
RAPID_COMMIT - org.onlab.packet.DHCP6.OptionCode
 
RARP - org.onlab.packet.EthType.EtherType
 
RARP - org.onosproject.cli.net.EthType
RARP.
rate() - Method in interface org.onosproject.cpman.ControlMessage
Returns the latest control message rate.
rate() - Method in class org.onosproject.cpman.DefaultControlMessage
 
rate() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
rate() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Rate of traffic subject to the SLAs specified for this token bucket.
rate() - Method in interface org.onosproject.net.meter.Band
The rate at which this meter applies.
rate() - Method in class org.onosproject.net.meter.DefaultBand
 
rate() - Method in class org.onosproject.net.pi.runtime.PiMeterBand
Returns the rate of this band.
rate() - Method in class org.onosproject.net.statistic.DefaultLoad
 
rate() - Method in interface org.onosproject.net.statistic.Load
Obtain the current observed rate (in bytes/s) on a link.
rate(long) - Method in class org.onosproject.cpman.MetricValue.Builder
Sets rate value.
rateLimit() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
Returns the rate limit set on the interface bandwidth.
rateLimit() - Method in interface org.onosproject.net.device.DeviceInterfaceDescription
Returns the rate limit set on the interface bandwidth.
RAW_DEVICE_CONFIG - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Raw device config.
rawData - Variable in class org.onlab.packet.RIP
 
reachableTime - Variable in class org.onlab.packet.ndp.RouterAdvertisement
 
REACTIVE - org.onosproject.net.packet.PacketPriority
Low priority for reactive applications.
read(Kryo, Input, Class<ImmutableList<?>>) - Method in class org.onosproject.store.serializers.ImmutableListSerializer
 
read(Kryo, Input, Class<ImmutableMap<?, ?>>) - Method in class org.onosproject.store.serializers.ImmutableMapSerializer
 
read(Kryo, Input, Class<ImmutableSet<?>>) - Method in class org.onosproject.store.serializers.ImmutableSetSerializer
 
read(Kryo, Input, Class<URI>) - Method in class org.onosproject.store.serializers.UriSerializer
 
read(Kryo, Input, Class<BitSet>) - Method in class org.onosproject.store.serializers.BitSetSerializer
 
read(Kryo, Input, Class<List<?>>) - Method in class org.onosproject.store.serializers.ArraysAsListSerializer
 
read(Kryo, Input, Class<Ip4Address>) - Method in class org.onosproject.store.serializers.Ip4AddressSerializer
 
read(Kryo, Input, Class<Ip4Prefix>) - Method in class org.onosproject.store.serializers.Ip4PrefixSerializer
 
read(Kryo, Input, Class<Ip6Address>) - Method in class org.onosproject.store.serializers.Ip6AddressSerializer
 
read(Kryo, Input, Class<Ip6Prefix>) - Method in class org.onosproject.store.serializers.Ip6PrefixSerializer
 
read(Kryo, Input, Class<IpAddress>) - Method in class org.onosproject.store.serializers.IpAddressSerializer
 
read(Kryo, Input, Class<IpPrefix>) - Method in class org.onosproject.store.serializers.IpPrefixSerializer
 
read(Kryo, Input, Class<MacAddress>) - Method in class org.onosproject.store.serializers.MacAddressSerializer
 
read(Kryo, Input, Class<ImmutableByteSequence>) - Method in class org.onosproject.store.serializers.ImmutableByteSequenceSerializer
 
read(Kryo, Input, Class<NodeId>) - Method in class org.onosproject.store.serializers.NodeIdSerializer
 
read(Kryo, Input, Class<DefaultApplicationId>) - Method in class org.onosproject.store.serializers.DefaultApplicationIdSerializer
 
read(Kryo, Input, Class<MastershipTerm>) - Method in class org.onosproject.store.serializers.MastershipTermSerializer
 
read(Kryo, Input, Class<ConnectPoint>) - Method in class org.onosproject.store.serializers.ConnectPointSerializer
 
read(Kryo, Input, Class<DefaultAnnotations>) - Method in class org.onosproject.store.serializers.AnnotationsSerializer
 
read(Kryo, Input, Class<DefaultLink>) - Method in class org.onosproject.store.serializers.DefaultLinkSerializer
 
read(Kryo, Input, Class<DefaultPort>) - Method in class org.onosproject.store.serializers.DefaultPortSerializer
 
read(Kryo, Input, Class<DeviceId>) - Method in class org.onosproject.store.serializers.DeviceIdSerializer
 
read(Kryo, Input, Class<FilteredConnectPoint>) - Method in class org.onosproject.store.serializers.FilteredConnectPointSerializer
 
read(Kryo, Input, Class<ExtensionCriterion>) - Method in class org.onosproject.store.serializers.ExtensionCriterionSerializer
 
read(Kryo, Input, Class<Instructions.ExtensionInstructionWrapper>) - Method in class org.onosproject.store.serializers.ExtensionInstructionSerializer
 
read(Kryo, Input, Class<HostLocation>) - Method in class org.onosproject.store.serializers.HostLocationSerializer
 
read(Kryo, Input, Class<LinkKey>) - Method in class org.onosproject.store.serializers.LinkKeySerializer
 
read(Kryo, Input, Class<DefaultOutboundPacket>) - Method in class org.onosproject.store.serializers.DefaultOutboundPacketSerializer
 
read(Kryo, Input, Class<PortNumber>) - Method in class org.onosproject.store.serializers.PortNumberSerializer
 
read(Kryo, Input, Class<ProviderId>) - Method in class org.onosproject.store.serializers.ProviderIdSerializer
 
read(Kryo, Input, Class<MastershipBasedTimestamp>) - Method in class org.onosproject.store.serializers.custom.MastershipBasedTimestampSerializer
 
readAllCounters(long) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Read the counter contents for all cell indices that are valid on the hardware switch.
readAllRegisterCells() - Method in interface org.onosproject.net.behaviour.PiRegisterProgrammable
Gets all of the register cells from the device.
readControlTrafficCounter() - Method in interface org.onosproject.net.behaviour.BngProgrammable
Read the control plane traffic counter of packets punted before attachment creation (e.g., when an attachment is not created yet).
readCounter(int) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Read the the given cell (Counter index) of the PDR counters from the given device.
readCounter(BngProgrammable.Attachment, BngProgrammable.BngCounterType) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Read a specific counter value of a specific attachment.
readCounters(BngProgrammable.Attachment) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Read all counters for a given attachment and returns a map with keys BngCounterType and values the ones obtained from the device.
readIntentFlows(List<Intent>) - Method in class org.onosproject.net.intent.util.IntentFilter
Finds all path (flow entries) corresponding to intent installables.
readme() - Method in interface org.onosproject.app.ApplicationDescription
Returns readme of the application.
readme() - Method in class org.onosproject.app.DefaultApplicationDescription
 
readme() - Method in interface org.onosproject.core.Application
Returns readme of the application.
readme() - Method in class org.onosproject.core.DefaultApplication
 
readOnly() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns if updates are disabled.
readRegisterCell(PiRegisterCellId) - Method in interface org.onosproject.net.behaviour.PiRegisterProgrammable
Gets the register cell given the register cell ID from the device.
readRegisterCells(Set<PiRegisterCellId>) - Method in interface org.onosproject.net.behaviour.PiRegisterProgrammable
Gets the register cells given the collection of cellIds from the device.
readRegisterCells(PiRegisterId) - Method in interface org.onosproject.net.behaviour.PiRegisterProgrammable
Gets all of the register cells given register ID from the device.
readTreeFromStream(ObjectMapper, InputStream) - Static method in class org.onlab.util.Tools
Utility to convert a mapper and an input stream into a JSON tree, and be tolerant of a null tree being returned.
READY - org.onosproject.cluster.ControllerNode.State
Signifies that the instance is active and that all components are operating normally.
READY - org.onosproject.net.pi.service.PiPipeconfWatchdogService.PipelineStatus
The device pipeline is ready to process packets.
REALLOCATING - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent is being reallocated.
REALLOCATING - org.onosproject.net.intent.IntentState
Indicates that the intent is being reallocated in a non-disruptive way NonDisruptiveConstraint.
reason() - Method in exception org.onosproject.net.config.InvalidFieldException
Returns the reason the field failed to validate.
reason() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
reason() - Method in interface org.onosproject.net.flow.FlowRule
Returns the reason for the flow received from switches.
reason() - Method in class org.onosproject.net.meter.MeterStoreResult
 
reasons() - Method in class org.onosproject.net.topology.TopologyEvent
Returns the list of events that triggered the topology change.
REBALANCE_ROLES_ON_UPGRADE - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
REBALANCE_ROLES_ON_UPGRADE_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
REBIND - org.onlab.packet.DHCP6.MsgType
 
reboot() - Method in interface org.onosproject.net.behaviour.BasicSystemOperations
Causes the target to reboot immediately.
receivedFrom() - Method in class org.onosproject.net.packet.DefaultInboundPacket
 
receivedFrom() - Method in interface org.onosproject.net.packet.InboundPacket
Returns the device and port from where the packet was received.
receivedRoleReply(DeviceId, MastershipRole) - Method in interface org.onosproject.net.device.DeviceProviderService
Notifies the core about a mastership role reported by the given device for this node.
receivedRoleReply(DeviceId, MastershipRole, MastershipRole) - Method in interface org.onosproject.net.device.DeviceProviderService
Notifies the core about the result of a role request sent to a device.
recent() - Method in class org.onosproject.cpman.ControlLoadSnapshot
Returns a set of historical recent of control metric.
recent(int, TimeUnit) - Method in interface org.onosproject.cpman.ControlLoad
Obtains the most recent metric values of the specified time duration.
recentMetric(String) - Method in interface org.onosproject.cpman.MetricsDatabase
Returns most recent metric value of a given metric type.
recentMetrics(String, int, TimeUnit) - Method in interface org.onosproject.cpman.MetricsDatabase
Return most recent metric values of a given metric type for a given period.
RECOMPILING - org.onosproject.net.intent.IntentState
Signifies that the intent is being recompiled into installable intents as an attempt to adapt to an anomaly in the network environment.
reconcileDevices(Set<DeviceId>) - Method in class org.onosproject.ui.model.topo.UiRegion
Make sure we have only these devices in the region.
reconcileHosts(Set<HostId>) - Method in class org.onosproject.ui.model.topo.UiRegion
Make sure we have only these hosts in the region.
RECONF_ACCEPT - org.onlab.packet.DHCP6.OptionCode
 
RECONF_MSG - org.onlab.packet.DHCP6.OptionCode
 
RECONFIGURE - org.onlab.packet.DHCP6.MsgType
 
recordEventTime(HybridLogicalTime) - Method in interface org.onosproject.core.HybridLogicalClockService
Records a (receive) event and accordingly makes adjustments to the hybrid logical time.
records() - Method in class org.onosproject.store.service.TransactionLog
Returns the list of transaction log records.
recordType - Variable in class org.onlab.packet.IGMPMembership
 
redAction() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the action to be taken for traffic marked as red.
redAction(BandwidthProfileAction) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the red action of this builder.
Redirect - Class in org.onlab.packet.ndp
Implements ICMPv6 Redirect packet format.
Redirect() - Constructor for class org.onlab.packet.ndp.Redirect
 
REDIRECT - org.onosproject.cli.net.Icmp6Type
Redirect Message.
REDIRECT - Static variable in class org.onlab.packet.ICMP6
Redirect Message.
referenceCount() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
referenceCount() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
Returns how many are referencing this policer.
referenceCount() - Method in class org.onosproject.net.group.DefaultGroup
 
referenceCount() - Method in interface org.onosproject.net.group.Group
Returns the number of flow rules or other groups reference this group.
referenceCount() - Method in class org.onosproject.net.meter.DefaultMeter
 
referenceCount() - Method in interface org.onosproject.net.meter.Meter
The number of flows pointing to this meter.
REFRESH - Static variable in class org.onosproject.ui.GlyphConstants
 
refreshModel() - Method in interface org.onosproject.ui.UiExtensionService
Refreshes the backing model.
region() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the identifier of the backing region.
region() - Method in interface org.onosproject.ui.model.ServiceBundle
Reference to a region service implementation.
region() - Method in class org.onosproject.ui.model.topo.UiRegionDeviceLink
Returns the identity of the region.
region() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the backing region with which this layout is associated.
region(Region) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the backing region for this layout.
region(RegionId) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the identifier of the backing region.
Region - Interface in org.onosproject.net.region
Representation of a group of devices located in a common physical or logical region.
REGION_ADDED - org.onosproject.net.region.RegionEvent.Type
Signifies that a new region was created.
REGION_ADDED_OR_UPDATED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
REGION_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
REGION_DEVICE - org.onosproject.ui.model.topo.UiLinkId.Type
 
REGION_MEMBERSHIP_CHANGED - org.onosproject.net.region.RegionEvent.Type
Signifies that a region device membership has changed.
REGION_READ - org.onosproject.security.AppPermission.Type
 
REGION_REGION - org.onosproject.ui.model.topo.UiLinkId.Type
 
REGION_REMOVED - org.onosproject.net.region.RegionEvent.Type
Signifies that a region was removed.
REGION_REMOVED - org.onosproject.ui.model.topo.UiModelEvent.Type
 
REGION_SUBJECT_FACTORY - Static variable in class org.onosproject.net.config.basics.SubjectFactories
Region ID subject factory.
REGION_UPDATED - org.onosproject.net.region.RegionEvent.Type
Signifies that a region was updated.
Region.Type - Enum in org.onosproject.net.region
Coarse representation of the type of the region.
regionA() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the identity of the first region.
regionA() - Method in class org.onosproject.ui.model.topo.UiRegionLink
Returns the identity of the first region.
RegionAddCommand - Class in org.onosproject.cli.net
Add a new region.
RegionAddCommand() - Constructor for class org.onosproject.cli.net.RegionAddCommand
 
RegionAddDevicesCommand - Class in org.onosproject.cli.net
Add a set of devices into existing region.
RegionAddDevicesCommand() - Constructor for class org.onosproject.cli.net.RegionAddDevicesCommand
 
RegionAddPeerLocCommand - Class in org.onosproject.cli.net
Annotate a region with a peer location.
RegionAddPeerLocCommand() - Constructor for class org.onosproject.cli.net.RegionAddPeerLocCommand
 
RegionAdminService - Interface in org.onosproject.net.region
Service for interacting with inventory of network control regions.
regionB() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the identity of the second region.
regionB() - Method in class org.onosproject.ui.model.topo.UiRegionLink
Returns the identity of the second region.
regionCount() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the number of regions configured in the topology.
RegionEvent - Class in org.onosproject.net.region
Describes region event.
RegionEvent(RegionEvent.Type, Region) - Constructor for class org.onosproject.net.region.RegionEvent
Creates an event of a given type and for the specified region and the current time.
RegionEvent(RegionEvent.Type, Region, Set<DeviceId>) - Constructor for class org.onosproject.net.region.RegionEvent
Creates an event of a given type and for the specified region, device id list and the current time.
RegionEvent(RegionEvent.Type, Region, Set<DeviceId>, long) - Constructor for class org.onosproject.net.region.RegionEvent
Creates an event of a given type and for the specified device and time.
RegionEvent.Type - Enum in org.onosproject.net.region
 
regionId() - Method in class org.onosproject.ui.model.topo.UiDevice
Returns the identifier of the region to which this device belongs.
regionId() - Method in class org.onosproject.ui.model.topo.UiHost
Returns the identifier of the region to which this device belongs.
regionId() - Method in class org.onosproject.ui.model.topo.UiSynthLink
Returns the region identifier.
regionId() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the identifier of the backing region.
regionId(String) - Static method in class org.onosproject.net.region.RegionId
Creates a new region identifier.
RegionId - Class in org.onosproject.net.region
Region identifier backed by a string value.
RegionIdCompleter - Class in org.onosproject.cli.net
Region ID completer.
RegionIdCompleter() - Constructor for class org.onosproject.cli.net.RegionIdCompleter
 
RegionListCommand - Class in org.onosproject.cli.net
List Region details including membership.
RegionListCommand() - Constructor for class org.onosproject.cli.net.RegionListCommand
 
RegionListener - Interface in org.onosproject.net.region
Entity capable of receiving region related events.
RegionRemoveCommand - Class in org.onosproject.cli.net
Removes a region from the existing region list.
RegionRemoveCommand() - Constructor for class org.onosproject.cli.net.RegionRemoveCommand
 
RegionRemoveDevicesCommand - Class in org.onosproject.cli.net
Remove a set of devices from existing region.
RegionRemoveDevicesCommand() - Constructor for class org.onosproject.cli.net.RegionRemoveDevicesCommand
 
RegionService - Interface in org.onosproject.net.region
Service for interacting with inventory of network control regions.
RegionStore - Interface in org.onosproject.net.region
Manages inventory of regions of devices; not intended for direct use.
RegionStoreDelegate - Interface in org.onosproject.net.region
Region store delegate abstraction.
RegionTypeCompleter - Class in org.onosproject.cli.net
Region type completer.
RegionTypeCompleter() - Constructor for class org.onosproject.cli.net.RegionTypeCompleter
 
RegionUpdateCommand - Class in org.onosproject.cli.net
Update an existing region.
RegionUpdateCommand() - Constructor for class org.onosproject.cli.net.RegionUpdateCommand
 
register(Serializer<?>, Class<?>...) - Method in class org.onlab.util.KryoNamespace.Builder
Registers serializer for the given set of classes.
register(Class<?>...) - Method in class org.onlab.util.KryoNamespace.Builder
Registers classes to be serialized using Kryo default serializer.
register(List<? extends Resource>) - Method in interface org.onosproject.net.resource.ResourceAdminService
Registers the specified resources.
register(List<? extends Resource>) - Method in interface org.onosproject.net.resource.ResourceStore
Registers the resources in transactional way.
register(KryoNamespace) - Method in class org.onlab.util.KryoNamespace.Builder
Registers all the class registered to given KryoNamespace.
register(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
Register application to SM-ONOS subsystem.
register(ApplicationId) - Static method in class org.onosproject.security.SecurityUtil
 
register(NetworkConfigRegistry) - Static method in class org.onosproject.routing.config.RoutingConfiguration
Registers the routing configuration factories.
register(PiPipeconf) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Registers the given pipeconf making it available to other subsystems.
register(PiRegisterId) - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns the register model associated with the given ID, if present.
register(Resource...) - Method in interface org.onosproject.net.resource.ResourceAdminService
Registers the specified resources.
register(ApiDocProvider) - Method in interface org.onosproject.rest.ApiDocService
Registers the specified REST API documentation provider.
register(UiExtension) - Method in interface org.onosproject.ui.UiExtensionService
Registers the specified user interface extension.
register(UiGlyphFactory) - Method in interface org.onosproject.ui.UiExtensionService
Registers the specified user interface glyph factory.
register(UiTopoHighlighterFactory) - Method in interface org.onosproject.ui.UiExtensionService
Registers the specified topo hilighter factory.
register(P) - Method in class org.onosproject.net.provider.AbstractProviderRegistry
 
register(P) - Method in interface org.onosproject.net.provider.ProviderRegistry
Registers the supplied provider with the core.
REGISTER_CELL - org.onosproject.net.pi.runtime.PiEntityType
Register cell.
registerApplication(String) - Method in interface org.onosproject.app.ApplicationIdStore
Registers a new application by its name, which is expected to follow the reverse DNS convention, e.g.
registerApplication(String) - Method in class org.onosproject.app.ApplicationIdStoreAdapter
 
registerApplication(String) - Method in interface org.onosproject.core.CoreService
Registers a new application by its name, which is expected to follow the reverse DNS convention, e.g.
registerApplication(String, Runnable) - Method in interface org.onosproject.core.CoreService
Registers a new application by its name, which is expected to follow the reverse DNS convention, e.g.
registerCodec(Class<T>, JsonCodec<T>) - Method in interface org.onosproject.codec.CodecService
Registers the specified JSON codec for the given entity class.
registerCompiler(Class<T>, IntentCompiler<T>) - Method in interface org.onosproject.net.intent.IntentExtensionService
Registers the specified compiler for the given intent class.
registerComponent(String) - Method in class org.onlab.metrics.MetricsManager
Registers a component.
registerComponent(String) - Method in interface org.onlab.metrics.MetricsService
Registers a component.
registerConfigFactory(ConfigFactory) - Method in interface org.onosproject.net.config.NetworkConfigRegistry
Registers the specified configuration factory.
registerConfigFactory(ConfigFactory) - Method in class org.onosproject.net.config.NetworkConfigRegistryAdapter
 
registerDeactivateHook(ApplicationId, Runnable) - Method in interface org.onosproject.app.ApplicationService
Registers application pre-deactivation processing hook.
REGISTERED - org.onosproject.net.pi.service.PiPipeconfEvent.Type
 
registerFeature(String) - Method in class org.onlab.metrics.MetricsComponent
 
registerFeature(String) - Method in interface org.onlab.metrics.MetricsComponentRegistry
Registers a Feature for this component.
registerHandler(String, BiConsumer<Endpoint, byte[]>, Executor) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Registers a new message handler for message type.
registerHandler(String, BiFunction<Endpoint, byte[], byte[]>, Executor) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Registers a new message handler for message type.
registerHandler(String, BiFunction<Endpoint, byte[], CompletableFuture<byte[]>>) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Registers a new message handler for message type.
registerId() - Method in class org.onosproject.net.pi.runtime.PiRegisterCellId
Returns the identifier of the register instance where this cell is contained.
registerInstaller(Class<T>, IntentInstaller<T>) - Method in interface org.onosproject.net.intent.IntentExtensionService
Registers the specific installer for the given intent class.
registerMetric(MetricsComponent, MetricsFeature, String, T) - Method in class org.onlab.metrics.MetricsManager
Registers an already created Metric.
registerMetric(MetricsComponent, MetricsFeature, String, T) - Method in interface org.onlab.metrics.MetricsService
Registers an already created Metric.
registerMetrics() - Method in class org.onlab.metrics.EventMetric
Registers the metrics.
registerNeighbourHandler(ConnectPoint, NeighbourMessageHandler, ApplicationId) - Method in interface org.onosproject.net.neighbour.NeighbourResolutionService
Registers a neighbour message handler for all neighbour messages incoming on the given connect point.
registerNeighbourHandler(Interface, NeighbourMessageHandler, ApplicationId) - Method in interface org.onosproject.net.neighbour.NeighbourResolutionService
Registers a neighbour message handler for all neighbour messages incoming on the given interface.
registerPortConfigOperator(PortConfigOperator, Class<? extends Config<ConnectPoint>>...) - Method in interface org.onosproject.net.config.PortConfigOperatorRegistry
Registers PortConfigOperator instance.
registerProperties(Class<?>) - Method in interface org.onosproject.cfg.ComponentConfigService
Registers configuration properties for the specified component.
registerProvider(DriverProvider) - Method in interface org.onosproject.net.driver.DriverAdminService
Registers the specified driver provider.
registerProxyService(Class<? super T>, T, Serializer) - Method in interface org.onosproject.cluster.ProxyService
Registers a proxy service.
registerProxyService(Class<? super T>, T, Serializer) - Method in interface org.onosproject.mastership.MastershipProxyService
Registers a proxy service.
registerReporter(MetricsReporter) - Method in class org.onlab.metrics.MetricsManager
Registers a reporter to receive any changes on metric registry.
registerReporter(MetricsReporter) - Method in interface org.onlab.metrics.MetricsService
Registers a reporter to receive any changes on metric registry.
registers() - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns all register models defined by this pipeline model.
registerTaskProcessor(Consumer<E>, int, Executor) - Method in interface org.onosproject.store.service.WorkQueue
Registers a task processing callback to be automatically invoked when new tasks are added to the work queue.
REJECT_ROUTE - org.onosproject.cli.net.Icmp6Code
Reject route to destination.
REJECT_ROUTE - Static variable in class org.onlab.packet.ICMP6
Reject route to destination.
RELATED_INTENTS - Static variable in class org.onosproject.ui.GlyphConstants
 
relaxedReadConsistency() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns if consistency is relaxed for read operations.
RELAY_AGENT_FLAGS - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
RELAY_FORW - org.onlab.packet.DHCP6.MsgType
 
RELAY_MSG - org.onlab.packet.DHCP6.OptionCode
 
RELAY_MSG_TYPES - Static variable in class org.onlab.packet.DHCP6
 
RELAY_REPL - org.onlab.packet.DHCP6.MsgType
 
release(Kryo) - Method in class org.onlab.util.KryoNamespace
 
release(List<ResourceAllocation>) - Method in interface org.onosproject.net.resource.ResourceService
Transactionally releases the specified resource allocations.
release(List<ResourceAllocation>) - Method in interface org.onosproject.net.resource.ResourceStore
Releases the specified allocated resources in transactional way.
release(ResourceAllocation) - Method in interface org.onosproject.net.resource.ResourceService
Releases the specified resource allocation.
release(ResourceAllocation...) - Method in interface org.onosproject.net.resource.ResourceService
Transactionally releases the specified resource allocations.
release(ResourceConsumer) - Method in interface org.onosproject.net.resource.ResourceService
Transactionally releases the resources allocated to the specified consumer.
RELEASE - org.onlab.packet.DHCP6.MsgType
 
releaseIP(HostId) - Method in interface org.onosproject.dhcp.DhcpStore
Releases the IP assigned to a Mac ID into the free pool.
releaseMapping(IntentId) - Method in interface org.onosproject.net.intent.IntentSetMultimap
Releases the mapping of the given intent.
relinquishAllRole(NodeId) - Method in interface org.onosproject.mastership.MastershipStore
Removes all the roles for the specified controller instance.
relinquishMastership(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Abandons mastership of the specified device on the local node thus forcing selection of a new master.
relinquishMastershipSync(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Synchronous version of relinquishMastership.
relinquishRole(NodeId, DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Allows a controller instance to give up its current role for a device.
REMARK - org.onosproject.net.behaviour.BandwidthProfileAction.Action
Traffic is allowed to pass after being appropriately remarked.
REMARK - org.onosproject.net.meter.Band.Type
Defines a simple DiffServ policer that remark the drop precedence of the DSCP field in the IP header of the packets that exceed the band rate value.
remote() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
remote() - Method in interface org.onosproject.net.behaviour.TunnelDescription
Returns the remote connection point.
remote(TunnelEndPoint) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
remote(TunnelEndPoint) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface description builder with a given remote tunnel endpoint.
REMOTE_ID - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
RemoteHandlerFailure() - Constructor for exception org.onosproject.store.cluster.messaging.MessagingException.RemoteHandlerFailure
 
remove() - Method in class org.onlab.util.UnmodifiableDeque
 
remove() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
remove() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
remove() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
remove() - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Builds the filtering objective that will be removed.
remove() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Builds the forwarding objective that will be removed.
remove() - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Builds the next objective that will be removed.
remove() - Method in interface org.onosproject.net.flowobjective.Objective.Builder
Builds the objective that will be removed.
remove() - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
remove() - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Requests the removal of a meter.
remove(E) - Method in interface org.onosproject.store.service.AsyncDistributedSet
Removes the specified element to this set if it is present (optional operation).
remove(E) - Method in interface org.onosproject.store.service.TransactionalSet
Removes the specified element from this set if it is present (optional operation).
remove(Object) - Method in class org.onlab.util.ExtendedSet
 
remove(Object) - Method in class org.onlab.util.UnmodifiableDeque
 
remove(Object) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
remove(Object) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
remove(Object, Object) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
remove(String) - Method in class org.onosproject.net.DefaultAnnotations.Builder
Adds the specified annotation.
remove(String) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
remove(String, long) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
remove(String, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
remove(K) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
remove(K) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
remove(K) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Removes and returns the value associated with key.
remove(K) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Removes the mapping for a key from this map if it is present (optional operation).
remove(K) - Method in interface org.onosproject.store.service.AtomicCounterMap
Removes and returns the value associated with key.
remove(K) - Method in interface org.onosproject.store.service.ConsistentMap
Removes the mapping for a key from this map if it is present (optional operation).
remove(K) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Removes the mapping associated with the specified key from the map.
remove(K) - Method in interface org.onosproject.store.service.TransactionalMap
Removes the mapping for a key from this map if it is present (optional operation).
remove(K, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
remove(K, long) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
remove(K, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
If (key, value) is currently in the map, this method removes it and returns true; otherwise, this method returns false.
remove(K, long) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Removes the entry for the specified key only if its current version in the map is equal to the specified version.
remove(K, long) - Method in interface org.onosproject.store.service.AtomicCounterMap
If (key, value) is currently in the map, this method removes it and returns true; otherwise, this method returns false.
remove(K, long) - Method in interface org.onosproject.store.service.ConsistentMap
Removes the entry for the specified key only if its current version in the map is equal to the specified version.
remove(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
remove(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
remove(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Removes the entry for the specified key only if it is currently mapped to the specified value.
remove(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Removes the key-value pair with the specified values if it exists.
remove(K, V) - Method in interface org.onosproject.store.service.ConsistentMap
Removes the entry for the specified key only if it is currently mapped to the specified value.
remove(K, V) - Method in interface org.onosproject.store.service.ConsistentMultimap
Removes the key-value pair with the specified values if it exists.
remove(K, V) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Removes the given key-value mapping from the map, if it exists.
remove(K, V) - Method in interface org.onosproject.store.service.TransactionalMap
Removes the entry for the specified key only if it is currently mapped to the specified value.
remove(AlarmId) - Method in interface org.onosproject.alarm.AlarmService
Remove an alarm from ONOS.
remove(ApplicationId) - Method in interface org.onosproject.app.ApplicationStore
Removes the specified application.
remove(ApplicationId) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
remove(ConnectPoint, String) - Method in interface org.onosproject.net.intf.InterfaceAdminService
Removes an interface configuration from the system.
remove(DomainIntent) - Method in interface org.onosproject.net.behaviour.DomainIntentConfigurable
Remove a intent in a domain.
remove(DomainIntent) - Method in class org.onosproject.net.domain.DomainIntentOperations.Builder
Appends a domain intent removal to the current stage.
remove(FlowRule) - Method in class org.onosproject.net.flow.FlowRuleOperations.Builder
Appends a flow rule remove to the current stage.
remove(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
remove(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
remove(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
remove(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Builds the filtering objective that will be removed.
remove(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Builds the forwarding objective that will be removed.
remove(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Builds the next objective that will be removed.
remove(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.Objective.Builder
Builds the objective that will be removed.
remove(McastRoute) - Method in interface org.onosproject.net.mcast.MulticastRouteService
Deprecated.
Removes a route from the information base.
remove(PiHandle) - Method in interface org.onosproject.net.pi.service.PiTranslationStore
Removes a previously added mapping for the given PI entity handle.
remove(UiClusterMember) - Method in class org.onosproject.ui.model.topo.UiTopology
Removes the given cluster member from the topology model.
remove(UiDevice) - Method in class org.onosproject.ui.model.topo.UiTopology
Removes the given device from the topology model.
remove(UiDeviceLink) - Method in class org.onosproject.ui.model.topo.UiTopology
Removes the given UI device link from the model.
remove(UiEdgeLink) - Method in class org.onosproject.ui.model.topo.UiTopology
Removes the given UI edge link from the model.
remove(UiHost) - Method in class org.onosproject.ui.model.topo.UiTopology
Removes the given host from the topology model.
remove(UiRegion) - Method in class org.onosproject.ui.model.topo.UiTopology
Removes the given region from the topology model.
REMOVE - org.onosproject.net.domain.DomainIntentOperation.Type
 
REMOVE - org.onosproject.net.flow.FlowRuleOperation.Type
 
REMOVE - org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry.FlowRuleOperation
Deprecated.
 
REMOVE - org.onosproject.net.flowobjective.Objective.Operation
Removes the objective.
REMOVE - org.onosproject.net.flowobjective.ObjectiveEvent.Type
Signifies that the objective has been removed.
REMOVE - org.onosproject.net.group.GroupStore.UpdateType
Modify existing group by removing provided information from it.
REMOVE - org.onosproject.net.intent.IntentInstaller.Direction
Direction for removing any installable objects(flows, configs...).
REMOVE - org.onosproject.net.mcast.McastStore.Type
Deprecated.
Removing a route from the mcast rib.
REMOVE - org.onosproject.net.meter.MeterOperation.Type
 
REMOVE - org.onosproject.net.meter.MeterRequest.Type
 
REMOVE - org.onosproject.store.service.EventuallyConsistentMapEvent.Type
Entry removed from map.
REMOVE - org.onosproject.store.service.MapEvent.Type
Entry removed from map.
REMOVE - org.onosproject.store.service.MultimapEvent.Type
Entry removed from map.
REMOVE - org.onosproject.store.service.SetEvent.Type
Entry removed from the set.
REMOVE_FROM_EXISTING - org.onosproject.net.flowobjective.Objective.Operation
Remove from an existing Next Objective.
REMOVE_IF_VERSION_MATCH - org.onosproject.store.primitives.MapUpdate.Type
Removes an entry if the current version matches specified version.
removeAccessMode(String) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
Removes an access interface to a VLAN.
removeActivePartitionMember(PartitionId, NodeId) - Method in interface org.onosproject.cluster.ClusterMetadataProvider
Removes a controller node from the list of active members for a partition.
removeAll(Collection<?>) - Method in class org.onlab.util.ExtendedSet
 
removeAll(Collection<?>) - Method in class org.onlab.util.UnmodifiableDeque
 
removeAll(Collection<?>) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
removeAll(Collection<? extends E>) - Method in interface org.onosproject.store.service.AsyncDistributedSet
Removes from this set all of its elements that are contained in the specified collection (optional operation).
removeAll(Map<K, Collection<? extends V>>) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
removeAll(Map<K, Collection<? extends V>>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Removes the set of key-value pairs with the specified key and values if they exist.
removeAll(Map<K, Collection<? extends V>>) - Method in interface org.onosproject.store.service.ConsistentMultimap
Removes the set of key-value pairs with the specified key and values if they exist.
removeAll(K) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
removeAll(K) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Removes all values associated with the specified key as well as the key itself.
removeAll(K) - Method in interface org.onosproject.store.service.ConsistentMultimap
Removes all values associated with the specified key as well as the key itself.
removeAll(K, Collection<? extends V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
removeAll(K, Collection<? extends V>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Removes the key-value pairs with the specified key and values if they exist.
removeAll(K, Collection<? extends V>) - Method in interface org.onosproject.store.service.ConsistentMultimap
Removes the key-value pairs with the specified key and values if they exist.
removeAllBandwidthProfiles() - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Removes all existing bandwidth profiles from a device.
removeAllButtons() - Method in class org.onosproject.ui.topo.PropertyPanel
Removes all currently defined buttons.
removeAllProps() - Method in class org.onosproject.ui.topo.PropertyPanel
Removes all currently defined properties.
removeAndGet(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
removeAndGet(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Removes the key-value pair with the specified values if it exists.
removeAndGet(K, V) - Method in interface org.onosproject.store.service.ConsistentMultimap
Removes the key-value pair with the specified values if it exists.
removeAttachment(BngProgrammable.Attachment) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Remove any state associated with the given attachment, including termination flow rules.
removeBandwidthProfile(String) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Removes an existing bandwidth profile from a device.
removeBandwidthProfile(Collection<String>) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Removes existing bandwidth profiles from a device.
removeBinding(DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfMappingStore
Removes device to pipeconf binding.
removeBucketsFromGroup(DeviceId, GroupKey, GroupBuckets, GroupKey, ApplicationId) - Method in interface org.onosproject.net.group.GroupService
Removes buckets from existing group.
removeButtons(ButtonId...) - Method in class org.onosproject.ui.topo.PropertyPanel
Removes buttons with the given descriptors from the list.
removeChangeListener(Consumer<Change<Leadership>>) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
removeChangeListener(Consumer<Change<Leadership>>) - Method in interface org.onosproject.store.service.AsyncLeaderElector
Unregisters a previously registered change notification listener.
removeChangeListener(Consumer<Change<Leadership>>) - Method in interface org.onosproject.store.service.LeaderElector
Unregisters a previously registered change notification listener.
removeConfig() - Method in interface org.onosproject.net.config.NetworkConfigService
Clears the complete configuration including queued.
removeConfig() - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
removeConfig(String, S, String) - Method in interface org.onosproject.net.config.NetworkConfigService
Clears any configuration for the specified subject and configuration key.
removeConfig(String, S, String) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
removeConfig(S) - Method in interface org.onosproject.net.config.NetworkConfigService
Clears the configuration including queued based on the subject.
removeConfig(S) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
removeConfig(S, Class<C>) - Method in interface org.onosproject.net.config.NetworkConfigService
Clears any configuration for the specified subject and configuration class.
removeConfig(S, Class<C>) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
removeConfigFactory(ConfigFactory) - Method in interface org.onosproject.net.config.NetworkConfigStore
Removes a configuration factory.
removeControllers(List<ControllerInfo>) - Method in interface org.onosproject.net.behaviour.ControllerConfig
Remove a list of controllers on a device.
REMOVED - org.onosproject.alarm.AlarmEvent.Type
Alarm set updated for a given device.
REMOVED - org.onosproject.net.flow.FlowEntry.FlowEntryState
Flow has been removed from flow table and can be purged.
REMOVED - org.onosproject.net.pi.service.PiPipeconfDeviceMappingEvent.Type
Individual mapping pipeconf to device removed.
removeDataPlaneEntity(DataPlaneEntity) - Method in class org.onosproject.net.PipelineTraceableHitChain
Removes the provided dataplane entity from the chain.
removeDevice(DeviceId) - Method in interface org.onosproject.net.device.DeviceAdminService
Removes the device with the specified identifier.
removeDevice(DeviceId) - Method in interface org.onosproject.net.device.DeviceStore
Administratively removes the specified device from the store.
removeDeviceAgentListener(ProviderId) - Method in interface org.onosproject.net.device.DeviceHandshaker
Removes a device agent listener previously registered for the given provider ID.
removeDevicePorts(DeviceId) - Method in interface org.onosproject.net.device.DeviceAdminService
Removes the ports of a device with the specified identifier.
removeDevices(RegionId, Collection<DeviceId>) - Method in interface org.onosproject.net.region.RegionAdminService
Removes the specified collection of devices from the region.
removeDevices(RegionId, Collection<DeviceId>) - Method in interface org.onosproject.net.region.RegionStore
Removes the specified collection of devices from the region.
removeDirectory(File) - Static method in class org.onlab.util.Tools
Purges the specified directory path. Use with great caution since no attempt is made to check for symbolic links, which could result in deletion of unintended files.
removeDirectory(String) - Static method in class org.onlab.util.Tools
Purges the specified directory path. Use with great caution since no attempt is made to check for symbolic links, which could result in deletion of unintended files.
removeDriver(Driver) - Method in class org.onosproject.net.driver.DefaultDriverProvider
Removes the specified driver from the provider.
removeDrivers(Set<Driver>) - Method in class org.onosproject.net.driver.DefaultDriverProvider
Removes the specified drivers from the provider.
removeEdge(E) - Method in class org.onlab.graph.DefaultMutablePath
 
removeEdge(E) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
removeEdge(E) - Method in interface org.onlab.graph.MutableGraph
Removes the specified edge from the graph.
removeEdge(E) - Method in interface org.onlab.graph.MutablePath
Removes the specified edge.
removeExtraneousGroupEntry(Group) - Method in interface org.onosproject.net.group.GroupStore
Remove the group entry from extraneous database.
removeFar(ForwardingActionRule) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Remove a previously installed Forwarding Action Rule (FAR) from the target device.
removeFilter(PacketInFilter) - Method in interface org.onosproject.net.packet.PacketService
Removes the specified filter from the filters list.
removeFirst() - Method in class org.onlab.util.UnmodifiableDeque
 
removeFirstOccurrence(Object) - Method in class org.onlab.util.UnmodifiableDeque
 
removeFlowRule(FlowEntry) - Method in interface org.onosproject.net.flow.FlowRuleStore
 
removeFlowRule(FlowRule...) - Method in interface org.onosproject.net.flow.FlowRuleProvider
Instructs the provider to remove the specified flow rules to their respective devices.
removeFlowRules(Collection<FlowRule>) - Method in interface org.onosproject.net.flow.FlowRuleProgrammable
Removes the specified collection of flow rules from the device.
removeFlowRules(FlowRule...) - Method in interface org.onosproject.net.flow.FlowRuleService
Removes the specified flow rules from their respective devices.
removeFlowRulesById(ApplicationId) - Method in interface org.onosproject.net.flow.FlowRuleService
Removes all rules submitted by a particular application.
removeFlowsInteractive(Iterable<FlowEntry>, FlowRuleService, CoreService) - Method in class org.onosproject.cli.net.FlowsListCommand
Removes the flows passed as argument after confirmation is provided for each of them.
removeFlowStatistic(FlowRule) - Method in interface org.onosproject.net.statistic.FlowStatisticStore
Remove entries associated with this rule.
removeFromExisting() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
removeFromExisting() - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Build the next objective that will be removed, with Objective.Operation REMOVE_FROM_EXISTING.
removeFromExisting(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
removeFromExisting(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Builds the next objective that will be removed, with Objective.Operation REMOVE_FROM_EXISTING.
removeFromStatistics(FlowRule) - Method in interface org.onosproject.net.statistic.StatisticStore
Remove entries associated with this rule.
removeGroup(DeviceId, GroupKey, ApplicationId) - Method in interface org.onosproject.net.group.GroupService
Deletes a group associated to an application cookie.
removeGroupEntry(Group) - Method in interface org.onosproject.net.group.GroupStore
Removes the group entry from store.
removeHost(HostId) - Method in interface org.onosproject.net.host.HostAdminService
Removes the end-station host with the specified identifier.
removeHost(HostId) - Method in interface org.onosproject.net.host.HostStore
Removes the specified host from the inventory.
removeIf(Predicate<? super E>) - Method in class org.onlab.util.UnmodifiableDeque
 
removeInterface(String) - Method in class org.onosproject.net.config.basics.InterfaceConfig
Removes an interface from the config.
removeInterface(UpfInterface) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Remove a previously installed UPF interface from the target device.
removeIntObjective(IntObjective) - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
Removes a given IntObjective entry from the device.
removeIp(HostId, IpAddress) - Method in interface org.onosproject.net.host.HostStore
Removes the specified ip from the host entry.
removeIpFromHost(HostId, IpAddress) - Method in interface org.onosproject.net.host.HostProviderService
Notifies the core when an IP is no longer associated with a host.
removeKey(DeviceKeyId) - Method in interface org.onosproject.net.key.DeviceKeyAdminService
Removes a device key from the store using the device key identifier.
removeLast() - Method in class org.onlab.util.UnmodifiableDeque
 
removeLastOccurrence(Object) - Method in class org.onlab.util.UnmodifiableDeque
 
removeLayout(UiTopoLayout) - Method in interface org.onosproject.ui.UiTopoLayoutService
Removes a layout from the system.
removeLink(ConnectPoint, ConnectPoint) - Method in interface org.onosproject.net.link.LinkAdminService
Removes all links between between the specified src and dst connection points.
removeLink(ConnectPoint, ConnectPoint) - Method in interface org.onosproject.net.link.LinkStore
Removes the link based on the specified information.
removeLinks(ConnectPoint) - Method in interface org.onosproject.net.link.LinkAdminService
Removes all infrastructure links leading to and from the specified connection point.
removeLinks(DeviceId) - Method in interface org.onosproject.net.link.LinkAdminService
Removes all infrastructure links leading to and from the specified device.
removeListener(L) - Method in class org.onosproject.event.AbstractListenerManager
 
removeListener(L) - Method in class org.onosproject.event.ListenerRegistry
 
removeListener(L) - Method in interface org.onosproject.event.ListenerService
Removes the specified listener.
removeListener(L) - Method in class org.onosproject.net.provider.AbstractListenerProviderRegistry
 
removeListener(NetworkConfigListener) - Method in class org.onosproject.net.config.NetworkConfigServiceAdapter
 
removeListener(DeviceListener) - Method in class org.onosproject.net.device.DeviceServiceAdapter
 
removeListener(DeviceListener) - Method in class org.onosproject.net.utils.ForwardingDeviceService
 
removeListener(ReplicaInfoEventListener) - Method in interface org.onosproject.store.flow.ReplicaInfoService
Removes the specified replica placement info change listener.
removeListener(AtomicValueEventListener<V>) - Method in class org.onosproject.store.primitives.DefaultAtomicValue
 
removeListener(AtomicValueEventListener<V>) - Method in interface org.onosproject.store.service.AsyncAtomicValue
Unregisters the specified listener such that it will no longer receive atomic value update notifications.
removeListener(AtomicValueEventListener<V>) - Method in interface org.onosproject.store.service.AtomicValue
Unregisters the specified listener such that it will no longer receive atomic value update notifications.
removeListener(DocumentTreeListener<V>) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
removeListener(DocumentTreeListener<V>) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Unregisters a previously added listener.
removeListener(DocumentTreeListener<V>) - Method in interface org.onosproject.store.service.DocumentTree
Unregisters a previously added listener.
removeListener(EventuallyConsistentMapListener<K, V>) - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Removes the specified listener from the map such that it will no longer receive change notifications.
removeListener(MapEventListener<String, V>) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
removeListener(MapEventListener<K, V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
removeListener(MapEventListener<K, V>) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Unregisters the specified listener such that it will no longer receive map change notifications.
removeListener(MapEventListener<K, V>) - Method in interface org.onosproject.store.service.ConsistentMap
Unregisters the specified listener such that it will no longer receive map change notifications.
removeListener(MultimapEventListener<K, V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
removeListener(MultimapEventListener<K, V>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Unregisters the specified listener such that it will no longer receive map change notifications.
removeListener(MultimapEventListener<K, V>) - Method in interface org.onosproject.store.service.ConsistentMultimap
Unregisters the specified listener such that it will no longer receive map change notifications.
removeListener(SetEventListener<E>) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
removeListener(SetEventListener<E>) - Method in interface org.onosproject.store.service.AsyncDistributedSet
Unregisters the specified listener.
removeListener(SetEventListener<E>) - Method in interface org.onosproject.store.service.DistributedSet
Unregisters the specified listener.
removeListeners() - Method in class org.onosproject.event.ListenerTracker
Removes all listeners in reverse order they have been registered.
removeLocation(HostId, HostLocation) - Method in interface org.onosproject.net.host.HostStore
Removes the specified location from the host entry.
removeLocationFromHost(HostId, HostLocation) - Method in interface org.onosproject.net.host.HostProviderService
Notifies the core when a location is no longer associated with a host.
removeMatching(MetricFilter) - Method in class org.onlab.metrics.MetricsManager
Removes all Metrics that match a given filter.
removeMatching(MetricFilter) - Method in interface org.onlab.metrics.MetricsService
Removes all Metrics that match a given filter.
removeMetric(MetricsComponent, MetricsFeature, String) - Method in class org.onlab.metrics.MetricsManager
Removes the metric with the given name.
removeMetric(MetricsComponent, MetricsFeature, String) - Method in interface org.onlab.metrics.MetricsService
Removes the metric with the given name.
removeMetrics() - Method in class org.onlab.metrics.EventMetric
Removes the metrics.
removeNextGroup(Integer) - Method in interface org.onosproject.net.flowobjective.FlowObjectiveStore
Remove a next group mapping from the store.
removeNode(NodeId) - Method in interface org.onosproject.cluster.ClusterStore
Removes the specified node from the inventory of cluster nodes.
removeNode(DocumentPath) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
removeNode(DocumentPath) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Removes the node with the specified path.
removeNode(DocumentPath) - Method in interface org.onosproject.store.service.DocumentTree
Removes the node with the specified path.
removeOrDownLink(ConnectPoint, ConnectPoint) - Method in interface org.onosproject.net.link.LinkStore
Removes the link, or marks it as inactive if the link is durable, based on the specified information.
removePatchMode(String) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
Removes a patch mode from the supplied interface.
removePdr(PacketDetectionRule) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Remove a previously installed Packet Detection Rule (PDR) from the target device.
removePeerFromSpeaker(BgpConfig.BgpSpeakerConfig, IpAddress) - Method in class org.onosproject.routing.config.BgpConfig
Removes peering address from BGP speaker.
removePendingContext(IntentOperationContext) - Method in class org.onosproject.net.intent.IntentInstallationContext
Removes a pending operation context.
removePendingHostLocation(MacAddress) - Method in interface org.onosproject.net.host.HostStore
Notifies HostStore the end of pending host location verification.
removeProbingHost(MacAddress) - Method in interface org.onosproject.net.host.HostProbeStore
Notifies HostProbeStore the end of pending host location verification.
removeProbingHost(MacAddress) - Method in interface org.onosproject.net.host.HostProbingProviderService
Notifies HostProbeStore the end of pending host location verification.
removeProcessor(PacketProcessor) - Method in interface org.onosproject.net.packet.PacketService
Removes the specified processor from the processing pipeline.
removeProps(String...) - Method in class org.onosproject.ui.topo.PropertyPanel
Removes properties with the given keys from the list.
removeQoS(PortNumber) - Method in interface org.onosproject.net.behaviour.PortConfigBehaviour
Remove a QoS configuration.
removeRateLimit(String) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
Removes rate limit from an interface.
removeRegion(RegionId) - Method in interface org.onosproject.net.region.RegionAdminService
Removes the specified region using the new set of data.
removeRegion(RegionId) - Method in interface org.onosproject.net.region.RegionStore
Removes the specified region using the new set of data.
removeRegistration(String) - Method in interface org.onosproject.cluster.LeadershipStore
Unregisters the local instance from leadership contest for topic.
removeRegistration(NodeId) - Method in interface org.onosproject.cluster.LeadershipStore
Unregisters an instance from all leadership contests.
removeSink(Class<E>) - Method in class org.onosproject.event.DefaultEventSinkRegistry
 
removeSink(Class<E>) - Method in interface org.onosproject.event.EventSinkRegistry
Removes the sink associated with the given event class.
removeSink(McastRoute, ConnectPoint) - Method in interface org.onosproject.net.mcast.MulticastRouteService
Deprecated.
Removes a sink from the route.
removeSpeaker(String) - Method in class org.onosproject.routing.config.BgpConfig
Removes BGP speaker from configuration.
removeStaticIP(MacAddress) - Method in interface org.onosproject.dhcp.DhcpStore
Removes a static IP mapping associated with the given MAC ID from the DHCP Server.
removeStaticMapping(MacAddress) - Method in interface org.onosproject.dhcp.DhcpService
Removes a static IP mapping with the DHCP Server.
removeStatusChangeListener(Consumer<DistributedPrimitive.Status>) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
removeStatusChangeListener(Consumer<DistributedPrimitive.Status>) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
removeStatusChangeListener(Consumer<DistributedPrimitive.Status>) - Method in interface org.onosproject.store.service.DistributedPrimitive
Unregisters a previously registered listener to be called when the primitive's status changes.
removeSubOption(byte) - Method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
Removes a sub-option by given sub-option code.
removeSubscriber(MessageSubject) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
Removes a subscriber for the specified message subject.
removeTrackedResources(Key, Collection<NetworkResource>) - Method in interface org.onosproject.net.intent.ObjectiveTrackerService
Removes a path flow to be tracked.
removeTrunkMode(String) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
Removes trunk mode configuration from an interface.
removeTunnelMode(String) - Method in interface org.onosproject.net.behaviour.InterfaceConfig
Removes a tunnel interface.
removeVertex(V) - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
removeVertex(V) - Method in interface org.onlab.graph.MutableGraph
Removes the specified vertex from the graph.
removeVlan(Collection<VlanId>) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Removes VLANs from a device.
removeVlan(VlanId) - Method in interface org.onosproject.net.behaviour.L2SwitchVlanConfigBehaviour
Removes a VLAN from a device.
RENEW - org.onlab.packet.DHCP6.MsgType
 
replace(String, long, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
replace(String, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
replace(String, V, V) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
replace(K, long, long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
replace(K, long, long) - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
If (key, expectedOldValue) is currently in the map, this method replaces expectedOldValue with newValue and returns true; otherwise, this method return false.
replace(K, long, long) - Method in interface org.onosproject.store.service.AtomicCounterMap
If (key, expectedOldValue) is currently in the map, this method replaces expectedOldValue with newValue and returns true; otherwise, this method return false.
replace(K, long, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
replace(K, long, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Replaces the entry for the specified key only if it is currently mapped to the specified version.
replace(K, long, V) - Method in interface org.onosproject.store.service.ConsistentMap
Replaces the entry for the specified key only if it is currently mapped to the specified version.
replace(K, V) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
replace(K, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
replace(K, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Replaces the entry for the specified key only if there is any value which associated with specified key.
replace(K, V) - Method in interface org.onosproject.store.service.ConsistentMap
Replaces the entry for the specified key only if there is any value which associated with specified key.
replace(K, V, V) - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
replace(K, V, V) - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
replace(K, V, V) - Method in interface org.onosproject.store.service.AsyncConsistentMap
Replaces the entry for the specified key only if currently mapped to the specified value.
replace(K, V, V) - Method in interface org.onosproject.store.service.ConsistentMap
Replaces the entry for the specified key only if currently mapped to the specified value.
replace(K, V, V) - Method in interface org.onosproject.store.service.TransactionalMap
Replaces the entry for the specified key only if currently mapped to the specified value.
replace(DocumentPath, V, long) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
replace(DocumentPath, V, long) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Conditionally updates a tree node if the current version matches a specified version.
replace(DocumentPath, V, long) - Method in interface org.onosproject.store.service.DocumentTree
Conditionally updates a tree node if the current version matches a specified version.
replace(DocumentPath, V, V) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
replace(DocumentPath, V, V) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Conditionally updates a tree node if the current node value matches a specified version.
replace(DocumentPath, V, V) - Method in interface org.onosproject.store.service.DocumentTree
Conditionally updates a tree node if the current value matches a specified value.
replaceAttributes(Map<String, String>) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
Replaces attributes with the specified Map.
replaceValues(K, Collection<V>) - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
replaceValues(K, Collection<V>) - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Stores all the values in values associated with the key specified, removes all preexisting values and returns a collection of the removed values which may be empty if the entry did not exist.
replaceValues(K, Collection<V>) - Method in interface org.onosproject.store.service.ConsistentMultimap
Stores all the values in values associated with the key specified, removes all preexisting values and returns a collection of the removed values which may be empty if the entry did not exist.
replicaInfo() - Method in class org.onosproject.store.flow.ReplicaInfoEvent
Returns the current replica information for the subject.
ReplicaInfo - Class in org.onosproject.store.flow
Class to represent placement information about Master/Backup copy.
ReplicaInfo(long, NodeId, List<NodeId>) - Constructor for class org.onosproject.store.flow.ReplicaInfo
Creates a ReplicaInfo instance.
ReplicaInfoEvent - Class in org.onosproject.store.flow
Describes a device replicainfo event.
ReplicaInfoEvent(ReplicaInfoEvent.Type, DeviceId, ReplicaInfo) - Constructor for class org.onosproject.store.flow.ReplicaInfoEvent
Creates an event of a given type and for the specified device, and replica info.
ReplicaInfoEvent.Type - Enum in org.onosproject.store.flow
Types of Replica info event.
ReplicaInfoEventListener - Interface in org.onosproject.store.flow
Entity capable of receiving Replica placement information-related events.
ReplicaInfoService - Interface in org.onosproject.store.flow
Service to return where the replica should be placed.
replicas() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
Returns the packet replicas provided by this clone session.
replicas() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
Returns the packet replicas provided by this multicast group.
replicationGroupTranslator() - Method in interface org.onosproject.net.pi.service.PiTranslationService
Returns a group translator for packet replication engine (PRE) entries.
reply(MacAddress) - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Replies to the request message with a given MAC address.
reply(NeighbourMessageContext, MacAddress) - Method in interface org.onosproject.net.neighbour.NeighbourMessageActions
Replies to an incoming request with the given MAC address.
REPLY - org.onlab.packet.DHCP6.MsgType
 
REPLY - org.onosproject.net.neighbour.NeighbourMessageType
Reply message.
REPLY_PACKET - org.onosproject.cpman.ControlMessage.Type
 
REPLY_PACKET - org.onosproject.cpman.ControlMetricType
 
reportProblem(E, Throwable) - Method in class org.onosproject.event.ListenerRegistry
Reports a problem encountered while processing an event.
request() - Method in class org.onosproject.net.intent.IntentData
 
REQUEST - org.onlab.packet.DHCP6.MsgType
 
REQUEST - org.onosproject.net.neighbour.NeighbourMessageType
Request message.
REQUEST - Static variable in class org.onlab.packet.EAP
 
REQUEST_PACKET - org.onosproject.cpman.ControlMessage.Type
 
REQUEST_PACKET - org.onosproject.cpman.ControlMetricType
 
requested(FlowRuleBatchRequest, DeviceId) - Static method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent
Deprecated.
Constructs a new FlowRuleBatchEvent.
RequestHandler - Class in org.onosproject.ui
Abstraction of an entity that handles a specific request from the user interface client.
RequestHandler(String) - Constructor for class org.onosproject.ui.RequestHandler
Constructs a request handler instance that will handle events of the specified type.
requestMac(IpAddress) - Method in interface org.onosproject.net.host.HostService
Requests the host service to resolve the MAC address for the given IP address.
requestPackets(TrafficSelector, PacketPriority, ApplicationId) - Method in interface org.onosproject.net.packet.PacketService
Requests that packets matching the given selector are punted from the dataplane to the controller.
requestPackets(TrafficSelector, PacketPriority, ApplicationId, Optional<DeviceId>) - Method in interface org.onosproject.net.packet.PacketService
Requests that packets matching the given selector are punted from the dataplane to the controller.
requestPackets(PacketRequest) - Method in interface org.onosproject.net.packet.PacketStore
Requests intercept of packets that match the given selector.
requestPackets(PacketRequest) - Method in interface org.onosproject.net.packet.PacketStoreDelegate
Requests that packets matching to following request be collected from all switches.
requestRole(DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Requests role of the local node for the specified device.
requestRoleFor(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Returns the mastership status of the local controller for a given device forcing master selection if necessary.
requestRoleForSync(DeviceId) - Method in interface org.onosproject.mastership.MastershipService
Synchronous version of requestRoleFor.
requiredApps() - Method in interface org.onosproject.app.ApplicationDescription
Returns list of required application names.
requiredApps() - Method in class org.onosproject.app.DefaultApplicationDescription
 
requiredApps() - Method in interface org.onosproject.core.Application
Returns list of required application names.
requiredApps() - Method in class org.onosproject.core.DefaultApplication
 
requiredLionBundles() - Method in class org.onosproject.ui.UiMessageHandler
Returns the set of identifiers for localization bundles that the message handler would like injected into itself, so that it can use those bundles in composing localized data to ship to the client.
requireNonDisruptive(Intent) - Static method in class org.onosproject.net.intent.constraint.NonDisruptiveConstraint
Determines whether the intent requires a non-disruptive reallocation.
requireProtectedPath(Intent) - Static method in class org.onosproject.net.intent.constraint.ProtectionConstraint
Determines whether to utilize path protection for the given intent.
reserved - Variable in class org.onlab.packet.PIM
 
reserved - Variable in class org.onlab.packet.RIP
 
reserved - Variable in class org.onlab.packet.RIPng
 
RESERVED - Static variable in class org.onlab.packet.VlanId
 
RESERVED_CODE - Static variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
RESERVED_CODE - Static variable in class org.onlab.packet.ndp.NeighborSolicitation
 
reset() - Method in class org.onlab.util.Counter
Resets the counter, by zeroing out the count and restarting the timer.
reset() - Method in interface org.onosproject.upgrade.UpgradeAdminService
Resets an upgrade.
reset(PiMeterCellId) - Static method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
Returns a PiMeterCellConfig with no bands.
RESET - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade has been reset.
RESET - org.onosproject.upgrade.UpgradeEvent.Type
Indicates that an upgrade was reset.
RESET_ZOOM - Static variable in class org.onosproject.ui.GlyphConstants
 
resetChecksum() - Method in class org.onlab.packet.BasePacket
 
resetChecksum() - Method in interface org.onlab.packet.IPacket
Reset any checksum as needed, and call resetChecksum on all parents.
resetChecksum() - Method in class org.onlab.packet.IPv4
 
resetChecksum() - Method in class org.onlab.packet.TCP
 
resetChecksum() - Method in class org.onlab.packet.UDP
 
resetControlTrafficCounter() - Method in interface org.onosproject.net.behaviour.BngProgrammable
Reset the control plane traffic counter of packets punted before attachment creation (e.g., when an attachment is not created yet).
resetCounter(BngProgrammable.Attachment, BngProgrammable.BngCounterType) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Reset the given counter of a specific attachment.
resetCounters(BngProgrammable.Attachment) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Reset the all the counters of a specific attachment.
resetProperty(ConfigProperty) - Static method in class org.onosproject.cfg.ConfigProperty
Creates a new configuration property as a copy of an existing one, but without a specific value, thus making it take its default value.
RESETTING - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade is being reset.
resField - Variable in class org.onlab.packet.IGMP
 
resource() - Method in class org.onosproject.net.resource.DiscreteFactory
Returns the resource for discrete-type.
resource() - Method in class org.onosproject.net.resource.ResourceAllocation
Returns the specifier of the resource this allocation uses.
resource(double) - Method in class org.onosproject.net.resource.ContinuousFactory
Returns the resource for continuous-type specified by the given value.
resource(String, String) - Method in class org.onosproject.ui.UiExtension
Returns input stream containing specified view-specific resource.
Resource - Interface in org.onosproject.net.resource
An object that represent a resource in a network.
RESOURCE_ADDED - org.onosproject.net.resource.ResourceEvent.Type
Signifies that a new resource has been detected.
RESOURCE_EVENT - org.onosproject.security.AppPermission.Type
 
RESOURCE_READ - org.onosproject.security.AppPermission.Type
 
RESOURCE_REMOVED - org.onosproject.net.resource.ResourceEvent.Type
Signifies that a resource has been removed.
RESOURCE_WRITE - org.onosproject.security.AppPermission.Type
 
ResourceAdminService - Interface in org.onosproject.net.resource
Service for administering resource service behavior.
ResourceAllocation - Class in org.onosproject.net.resource
Represents allocation of resource which is identified by the specifier.
ResourceAllocation(Resource, ResourceConsumer) - Constructor for class org.onosproject.net.resource.ResourceAllocation
Creates an instance with the specified subject, resource and consumer.
ResourceAllocation(Resource, ResourceConsumerId) - Constructor for class org.onosproject.net.resource.ResourceAllocation
Creates an instance with the specified subject, resource and consumerId.
ResourceConsumer - Interface in org.onosproject.net.resource
Marker interface representing an entity using resource.
ResourceConsumerId - Class in org.onosproject.net.resource
Representation of global unique ID for ResourceConsumer object.
ResourceConsumerId() - Constructor for class org.onosproject.net.resource.ResourceConsumerId
 
ResourceContext - Interface in org.onosproject.net.intent
Class providing resource information to constraints.
ResourceEvent - Class in org.onosproject.net.resource
Describes an event related to a resource.
ResourceEvent(ResourceEvent.Type, Resource) - Constructor for class org.onosproject.net.resource.ResourceEvent
Create a resource event.
ResourceEvent.Type - Enum in org.onosproject.net.resource
Type of resource events.
resourceGroup - Variable in class org.onosproject.net.intent.Intent.Builder
 
resourceGroup() - Method in class org.onosproject.cli.net.ConnectivityIntentCommand
 
resourceGroup() - Method in class org.onosproject.net.intent.Intent
Returns the resource group for this intent.
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.Intent.Builder
Sets the resource group for this intent.
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.PathIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
 
resourceGroup(ResourceGroup) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
 
ResourceGroup - Class in org.onosproject.net
Intent identifier suitable as an external key.
ResourceGroup() - Constructor for class org.onosproject.net.ResourceGroup
Constructor for serializer.
ResourceGroup(long) - Constructor for class org.onosproject.net.ResourceGroup
Constructs the ID corresponding to a given long value.
ResourceId - Class in org.onosproject.net.resource
Represents identifier of resource.
ResourceId() - Constructor for class org.onosproject.net.resource.ResourceId
 
ResourceListener - Interface in org.onosproject.net.resource
Entity capable of receiving resource related events.
resourceName() - Method in interface org.onosproject.cpman.MetricsDatabase
Returns the resource name of this database.
resourcePath(String) - Method in class org.onosproject.ui.UiExtension.Builder
Set the resource path.
ResourceQueryService - Interface in org.onosproject.net.resource
Service for retrieving resource information.
resources - Variable in class org.onosproject.net.intent.Intent.Builder
 
resources() - Method in class org.onosproject.net.intent.Intent
Returns the collection of resources required for this intent.
resources(Collection<Link>) - Static method in class org.onosproject.net.domain.DomainPointToPointIntent
Produces a collection of network resources from the given links.
resources(Collection<Link>) - Static method in class org.onosproject.net.intent.ConnectivityIntent
Produces a collection of network resources from the given links.
resources(Collection<NetworkResource>) - Method in class org.onosproject.net.intent.Intent.Builder
Sets the collection of resources required for this intent.
resources(Collection<NetworkResource>) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
 
resources(Collection<NetworkResource>) - Method in class org.onosproject.net.intent.ProtectionEndpointIntent.Builder
 
resources(Collection<NetworkResource>, Collection<Link>) - Static method in class org.onosproject.net.intent.ConnectivityIntent
Produces a collection of network resources from the given links.
Resources - Class in org.onosproject.net.resource
Utility class for resource related classes.
ResourcesCommand - Class in org.onosproject.cli.net
Lists registered resources.
ResourcesCommand() - Constructor for class org.onosproject.cli.net.ResourcesCommand
 
ResourceService - Interface in org.onosproject.net.resource
Service for allocating/releasing resource(s) and retrieving allocation(s) and availability.
ResourceStore - Interface in org.onosproject.net.resource
Service for storing resource and consumer information.
ResourceStoreDelegate - Interface in org.onosproject.net.resource
Resource store delegate abstraction.
respond(byte[]) - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
Records the response to be sent to the sender.
response() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
Returns the response to be sent to the sender.
response(Response.Status, Throwable) - Method in class org.onlab.rest.exceptions.AbstractMapper
Produces a response builder primed with the supplied status code and JSON entity with the status code and exception message.
RESPONSE - Static variable in class org.onlab.packet.EAP
 
responseStatus() - Method in class org.onlab.rest.exceptions.AbstractMapper
Returns the response status to be given when the exception occurs.
responseStatus() - Method in class org.onlab.rest.exceptions.BadRequestMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.EntityNotFoundMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.ForbiddenMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.IllegalArgumentExceptionMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.IllegalStateExceptionMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.NotFoundMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.ServerErrorMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.ServiceNotFoundMapper
 
responseStatus() - Method in class org.onlab.rest.exceptions.WebApplicationExceptionMapper
 
REST_SERVER - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for REST server identifier.
restartReport() - Method in interface org.onlab.metrics.MetricsReporter
Restarts metrics reporter.
RESTORED - org.onosproject.mastership.MastershipEvent.Type
Signifies that the underlying storage for the Mastership state of this device became available again.
result() - Method in class org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent
Deprecated.
Returns the result of this batch operation.
result() - Method in class org.onosproject.net.PipelineTraceableOutput
Returns the result of the computation.
retainAll(Collection<?>) - Method in class org.onlab.util.ExtendedSet
 
retainAll(Collection<?>) - Method in class org.onlab.util.UnmodifiableDeque
 
retainAll(Collection<?>) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
retainAll(Collection<? extends E>) - Method in interface org.onosproject.store.service.AsyncDistributedSet
Retains only the elements in this set that are contained in the specified collection (optional operation).
retransmitTimer - Variable in class org.onlab.packet.ndp.RouterAdvertisement
 
RetriesExceededException - Exception in org.onlab.util
Exception that indicates the retry threshold has been exceeded.
retry() - Method in interface org.onosproject.net.host.HostProbe
Gets retry counter of this entry.
retryable(Function<U, V>, Class<? extends Throwable>, int, int) - Static method in class org.onlab.util.Tools
Returns a function that retries execution on failure.
retryable(Supplier<V>, Class<? extends Throwable>, int, int) - Static method in class org.onlab.util.Tools
Returns a Supplier that retries execution on failure.
RetryingFunction<U,​V> - Class in org.onlab.util
Function that retries execution on failure.
RetryingFunction(Function<U, V>, Class<? extends Throwable>, int, int) - Constructor for class org.onlab.util.RetryingFunction
 
REVERSE_PORT_ANNOTATION_KEY - Static variable in class org.onosproject.net.intent.OpticalPathIntent
 
review(ApplicationId) - Method in interface org.onosproject.security.SecurityAdminService
Changes SecurityModeState of specified application to REVIEWED.
ReviewApplicationNameCompleter - Class in org.onosproject.cli.security
Application name completer for security review command.
ReviewApplicationNameCompleter() - Constructor for class org.onosproject.cli.security.ReviewApplicationNameCompleter
 
ReviewCommand - Class in org.onosproject.cli.security
Application security policy review commands.
ReviewCommand() - Constructor for class org.onosproject.cli.security.ReviewCommand
 
revisionType() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns the primitive revision type.
RevisionType - Enum in org.onosproject.store.service
Distributed primitive revision types.
revokeToken(UiSessionToken) - Method in interface org.onosproject.ui.UiTokenService
Revokes the specified session token.
RichComparable<T> - Interface in org.onlab.util
Extends useful methods for comparison to Comparable interface.
RIP - Class in org.onlab.packet
Implements RIP Packet format, according to RFC 2453.
RIP() - Constructor for class org.onlab.packet.RIP
 
RIP_PORT - Static variable in class org.onlab.packet.UDP
 
RIP.CmdType - Enum in org.onlab.packet
 
RIPng - Class in org.onlab.packet
Representation of an RIPng Packet.
RIPng() - Constructor for class org.onlab.packet.RIPng
 
RIPNG_PORT - Static variable in class org.onlab.packet.UDP
 
RIPng.CmdType - Enum in org.onlab.packet
 
RIPngEntry - Class in org.onlab.packet
Default DHCP option.
RIPngEntry() - Constructor for class org.onlab.packet.RIPngEntry
 
RIPngREQUEST - org.onlab.packet.RIPng.CmdType
 
RIPngRESPONSE - org.onlab.packet.RIPng.CmdType
 
RIPREQUEST - org.onlab.packet.RIP.CmdType
 
RIPRESPONSE - org.onlab.packet.RIP.CmdType
 
RIPV2AuthEntry - Class in org.onlab.packet
 
RIPV2AuthEntry() - Constructor for class org.onlab.packet.RIPV2AuthEntry
 
RIPV2Entry - Class in org.onlab.packet
 
RIPV2Entry() - Constructor for class org.onlab.packet.RIPV2Entry
 
ROADM - org.onosproject.net.Device.Type
 
ROADM - Static variable in class org.onosproject.ui.GlyphConstants
 
ROADM_OTN - org.onosproject.net.Device.Type
 
ROADM_OTN - Static variable in class org.onosproject.ui.GlyphConstants
 
role() - Method in interface org.onosproject.app.ApplicationDescription
Returns the role of the application.
role() - Method in class org.onosproject.app.DefaultApplicationDescription
 
role() - Method in interface org.onosproject.core.Application
Returns the role of the application.
role() - Method in class org.onosproject.core.DefaultApplication
 
ROLE_MASTER - org.onosproject.net.device.DeviceAgentEvent.Type
Signifies that the agent has acquired master role.
ROLE_NONE - org.onosproject.net.device.DeviceAgentEvent.Type
Signifies that the agent doesn't have any valid mastership role for the device.
ROLE_STANDBY - org.onosproject.net.device.DeviceAgentEvent.Type
Signifies that the agent has acquired standby/slave mastership role.
roleChanged(int, long) - Method in interface org.onosproject.net.device.DeviceHandshaker
Notifies the device of a mastership role change as decided by the core.
roleChanged(DeviceId, MastershipRole) - Method in interface org.onosproject.net.device.DeviceProvider
Notifies the provider of a mastership role change for the specified device as decided by the core.
roleChanged(MastershipRole) - Method in interface org.onosproject.net.device.DeviceHandshaker
Notifies the device a mastership role change as decided by the core.
RoleCompleter - Class in org.onosproject.cli.net
Device mastership role completer.
RoleCompleter() - Constructor for class org.onosproject.cli.net.RoleCompleter
 
roleInfo() - Method in class org.onosproject.mastership.MastershipEvent
Deprecated.
since 1.14
RoleInfo - Class in org.onosproject.cluster
An immutable container for role information for a device, within the current cluster.
RoleInfo() - Constructor for class org.onosproject.cluster.RoleInfo
 
RoleInfo(NodeId, List<NodeId>) - Constructor for class org.onosproject.cluster.RoleInfo
 
roles() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns set of roles assigned to the element.
roles(Set<String>) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the roles of the element.
ROLES - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for roles.
RolesCommand - Class in org.onosproject.cli
Lists mastership roles of nodes for each device.
RolesCommand() - Constructor for class org.onosproject.cli.RolesCommand
 
rollback() - Method in interface org.onosproject.upgrade.UpgradeAdminService
Rolls back an upgrade.
rollback(TransactionId) - Method in interface org.onosproject.store.service.Transactional
Aborts a previously prepared transaction and unlocks the object.
ROLLED_BACK - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade has been rolled back.
ROLLED_BACK - org.onosproject.upgrade.UpgradeEvent.Type
Indicates that an upgrade was rolled back.
ROLLING_BACK - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade is being rolled back.
ROOM - org.onosproject.net.region.Region.Type
Region represents a room.
root() - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
root() - Method in interface org.onosproject.net.topology.TopologyCluster
Returns the cluster root vertex.
root() - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
root() - Method in interface org.onosproject.store.service.AsyncDocumentTree
Returns the path to root of the tree.
root() - Method in interface org.onosproject.store.service.DocumentTree
Returns the path to root of the tree.
ROOT - Static variable in interface org.onosproject.net.resource.Resource
 
ROOT - Static variable in class org.onosproject.store.service.DocumentPath
Root document tree path.
route() - Method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
The route associated with this multicast information.
ROUTE - org.onosproject.cli.net.ExtHeader
Router header.
ROUTE_ADDED - org.onosproject.net.mcast.McastEvent.Type
Deprecated.
A new mcast route has been added.
ROUTE_REMOVED - org.onosproject.net.mcast.McastEvent.Type
Deprecated.
A mcast route has been removed.
Router - Class in org.onosproject.routing
Manages the configuration and provisioning of a single-device router.
Router(RouterInfo, InterfaceService, DeviceService, Consumer<InterfaceProvisionRequest>, Consumer<InterfaceProvisionRequest>, boolean) - Constructor for class org.onosproject.routing.Router
Creates a new router interface manager.
ROUTER - org.onosproject.net.Device.Type
 
ROUTER - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Router header present.
ROUTER - Static variable in class org.onosproject.ui.GlyphConstants
 
ROUTER_ADVERTISEMENT - org.onosproject.cli.net.Icmp6Type
Router Advertisement.
ROUTER_ADVERTISEMENT - Static variable in class org.onlab.packet.ICMP6
Router Advertisement.
ROUTER_APP_ID - Static variable in interface org.onosproject.routing.RoutingService
 
ROUTER_CONFIG_CLASS - Static variable in interface org.onosproject.routing.RoutingService
 
ROUTER_ID - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the router ID.
ROUTER_SOLICITATION - org.onosproject.cli.net.Icmp6Type
Router Solicitation.
ROUTER_SOLICITATION - Static variable in class org.onlab.packet.ICMP6
Router Solicitation.
routerAddress() - Method in class org.onosproject.dhcp.IpAssignment
Returns router address of the IP assignment.
routerAddress(Ip4Address) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
RouterAdvertisement - Class in org.onlab.packet.ndp
Implements ICMPv6 Router Advertisement packet format.
RouterAdvertisement() - Constructor for class org.onlab.packet.ndp.RouterAdvertisement
 
RouterConfig - Class in org.onosproject.routing.config
Deprecated.
in Junco release. Use RoutersConfig instead.
RouterConfig() - Constructor for class org.onosproject.routing.config.RouterConfig
Deprecated.
 
routerFlag - Variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
RouterInfo - Class in org.onosproject.routing
Stores configuration information about a router.
RouterInfo(ConnectPoint, boolean, Set<String>) - Constructor for class org.onosproject.routing.RouterInfo
Creates a new router info.
routerLifetime - Variable in class org.onlab.packet.ndp.RouterAdvertisement
 
RoutersConfig - Class in org.onosproject.routing.config
Routing configuration.
RoutersConfig() - Constructor for class org.onosproject.routing.config.RoutersConfig
 
RoutersConfig.Router - Class in org.onosproject.routing.config
Router configuration.
RouterSolicitation - Class in org.onlab.packet.ndp
Implements ICMPv6 Router Solicitation packet format.
RouterSolicitation() - Constructor for class org.onlab.packet.ndp.RouterSolicitation
 
routeTag - Variable in class org.onlab.packet.RIPngEntry
 
routeTag - Variable in class org.onlab.packet.RIPV2Entry
 
Routing - Class in org.onlab.packet.ipv6
Implements IPv6 routing extension header format.
Routing() - Constructor for class org.onlab.packet.ipv6.Routing
 
RoutingConfiguration - Class in org.onosproject.routing.config
Helper class to manage routing configurations.
routingData - Variable in class org.onlab.packet.ipv6.Routing
 
RoutingService - Interface in org.onosproject.routing
Historical interface now used only as a centralised place to define routing config related constants.
routingType - Variable in class org.onlab.packet.ipv6.Routing
 
Row() - Constructor for class org.onosproject.ui.table.TableModel.Row
 
rowCount() - Method in class org.onosproject.ui.table.TableModel
Returns the number of rows in this table model.
RST - org.onosproject.net.flow.criteria.Criterion.TcpFlags
Reset the connection.
rsvd1 - Variable in class org.onlab.packet.VXLAN
 
rsvd2 - Variable in class org.onlab.packet.VXLAN
 
rtEntries - Variable in class org.onlab.packet.RIP
 
rtEntries - Variable in class org.onlab.packet.RIPng
 
rule() - Method in class org.onosproject.net.flow.FlowRuleOperation
Returns the flow rule.
RULE_ADD_REQUESTED - org.onosproject.net.flow.FlowRuleEvent.Type
 
RULE_ADDED - org.onosproject.net.flow.FlowRuleEvent.Type
Signifies that a new flow rule has been detected.
RULE_REMOVE_REQUESTED - org.onosproject.net.flow.FlowRuleEvent.Type
 
RULE_REMOVED - org.onosproject.net.flow.FlowRuleEvent.Type
Signifies that a flow rule has been removed.
RULE_UPDATED - org.onosproject.net.flow.FlowRuleEvent.Type
Signifies that a rule has been updated.
run() - Method in class org.onlab.util.Generator
 
run() - Method in class org.onlab.util.SafeRecurringTask
 
run(KryoCallback<T>) - Method in class org.onlab.util.KryoNamespace
 
run(String, NodeId) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
run(String, NodeId) - Method in interface org.onosproject.store.service.AsyncLeaderElector
Attempts to become leader for a topic.
run(String, NodeId) - Method in interface org.onosproject.store.service.LeaderElector
Attempts to become leader for a topic.
runAfterBoth(CompletionStage<?>, Runnable) - Method in class org.onlab.util.BlockingAwareFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class org.onlab.util.BlockingAwareFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class org.onlab.util.BlockingAwareFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class org.onlab.util.BlockingAwareFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
runForLeadership(String) - Method in interface org.onosproject.cluster.LeadershipService
Enters a leadership contest.

S

s(Object) - Method in class org.onosproject.cli.net.IntentDetailsCommand
 
S_BAND_MAX - Static variable in class org.onlab.util.Spectrum
 
S_BAND_MIN - Static variable in class org.onlab.util.Spectrum
 
safeName(Region) - Static method in class org.onosproject.ui.model.topo.UiRegion
Guarantees to return a string for the name of the specified region.
SafeRecurringTask - Class in org.onlab.util
Wrapper for a recurring task which catches all exceptions to prevent task being suppressed in a ScheduledExecutorService.
SAK_FIELD_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
samenessThreshold() - Static method in class org.onlab.graph.ScalarWeight
Returns the current sameness threshold for comparing cost values.
saveApplication(InputStream) - Method in class org.onosproject.common.app.ApplicationArchive
Loads the application descriptor from the specified application archive stream and saves the stream in the appropriate application archive directory.
ScalarWeight - Class in org.onlab.graph
Weight implementation based on a double value.
ScalarWeight(double) - Constructor for class org.onlab.graph.ScalarWeight
Creates a new scalar weight with the given double value.
scale() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the scale for the geomap / sprites background.
scale() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the scale for the geomap / sprite image.
scale() - Method in class org.onosproject.ui.UiTopoMap
Returns the scale for this map.
scale(double) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the scale for the geomap / sprite image.
scale(Double) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the scale for the geomap / sprites background.
schedule(Runnable, long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
 
schedule(Runnable, long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
 
schedule(Runnable, long, TimeUnit, boolean) - Method in class org.onlab.util.SharedScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit, boolean) - Method in class org.onlab.util.SharedScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period; that is executions will commence after initialDelay then initialDelay+period, then initialDelay + 2 * period, and so on.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.onlab.junit.NullScheduledExecutor
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.onlab.util.SharedScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit, boolean) - Method in class org.onlab.util.SharedScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
scheme() - Method in class org.onosproject.net.provider.ProviderId
Returns the device URI scheme to which this provider is bound.
SCHEMES - Static variable in class org.onosproject.alarm.AlarmEntityId
 
SCI(byte[]) - Constructor for class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
To set SCI from MAC address and port stream.
SCI(byte[], short) - Constructor for class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
To set SCI from MAC address and port number.
scope() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
scope() - Method in class org.onosproject.net.meter.DefaultMeterRequest
 
scope() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns Meter Scope.
scope() - Method in interface org.onosproject.net.meter.MeterRequest
Returns the scope of this meter request.
scope() - Method in class org.onosproject.net.meter.MeterTableKey
 
ScrListCommand - Class in org.onosproject.cli
CLI command to dump out the SCR components list in the old karaf format.
ScrListCommand() - Constructor for class org.onosproject.cli.ScrListCommand
 
SCTP_DST - org.onosproject.net.flow.criteria.Criterion.Type
SCTP destination port.
SCTP_DST_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
SCTP destination port with masking.
SCTP_SRC - org.onosproject.net.flow.criteria.Criterion.Type
SCTP source port.
SCTP_SRC_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
SCTP source port with masking.
sctpPort() - Method in class org.onosproject.net.flow.criteria.SctpPortCriterion
Gets the SCTP port to match.
SctpPortCriterion - Class in org.onosproject.net.flow.criteria
Implementation of SCTP port criterion (16 bits unsigned integer).
search(Graph<V, E>, EdgeWeigher<V, E>) - Method in interface org.onlab.graph.GraphSearch
Searches the specified graph.
search(Graph<V, E>, EdgeWeigher<V, E>) - Method in class org.onlab.graph.TarjanGraphSearch
Searches the specified graph.
search(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in class org.onlab.graph.AbstractGraphPathSearch
 
search(Graph<V, E>, V, V, EdgeWeigher<V, E>, int) - Method in interface org.onlab.graph.GraphPathSearch
Searches the specified graph for paths between vertices.
secondary() - Method in class org.onlab.graph.DisjointPathPair
Returns the secondary path.
SECONDARY_HIGHLIGHT - org.onosproject.ui.topo.LinkHighlight.Flavor
 
seconds - Variable in class org.onlab.packet.bmp.BmpPeer
 
seconds - Variable in class org.onlab.packet.DHCP
 
SECURE - org.onosproject.net.behaviour.BridgeDescription.FailMode
The bridge will not set up flows on its own when the controller connection fails or no controllers are defined.
SecurityAdminService - Interface in org.onosproject.security
Security-Mode ONOS service.
securityParamIndex - Variable in class org.onlab.packet.ipv6.Authentication
 
securityParamIndex - Variable in class org.onlab.packet.ipv6.EncapSecurityPayload
 
SecurityUtil - Class in org.onosproject.security
Utility class to aid Security-Mode ONOS.
segmentsLeft - Variable in class org.onlab.packet.ipv6.Routing
 
SELECT - org.onosproject.net.group.GroupDescription.Type
Load-balancing among different buckets in a group.
selector - Variable in class org.onosproject.net.intent.ConnectivityIntent.Builder
 
selector() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective
Returns traffic selector of this objective.
selector() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
selector() - Method in interface org.onosproject.net.flow.FlowRule
Returns the traffic selector that identifies what traffic this rule should apply to.
selector() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
selector() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective
Obtain the selector for this objective.
selector() - Method in class org.onosproject.net.intent.ConnectivityIntent
Returns the match specifying the type of traffic.
selector() - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
selector() - Method in interface org.onosproject.net.packet.PacketRequest
Obtains the traffic selector.
selector(TrafficSelector) - Method in class org.onosproject.net.intent.ConnectivityIntent.Builder
Sets the traffic selector for the intent that will be built.
selector(TrafficSelector) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.PathIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
 
selector(TrafficSelector) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
 
send() - Method in class org.onosproject.net.packet.DefaultPacketContext
 
send() - Method in interface org.onosproject.net.packet.PacketContext
Triggers the outbound packet to be sent.
sendAndReceive(M, MessageSubject, Function<M, byte[]>, Function<byte[], R>, NodeId) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
Sends a message and expects a reply.
sendAndReceive(M, MessageSubject, Function<M, byte[]>, Function<byte[], R>, NodeId, Duration) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
Sends a message and expects a reply.
sendAndReceive(Endpoint, String, byte[]) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Sends a message asynchronously and expects a response.
sendAndReceive(Endpoint, String, byte[], Duration) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Sends a message asynchronously and expects a response.
sendAndReceive(Endpoint, String, byte[], Duration, Executor) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Sends a message synchronously and expects a response.
sendAndReceive(Endpoint, String, byte[], Executor) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Sends a message synchronously and expects a response.
sendAsync(Endpoint, String, byte[]) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Sends a message asynchronously to the specified communication end point.
sender() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the source IP address of the message.
sender() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
Returns the id of the controller sending this message.
senderHardwareAddress - Variable in class org.onlab.packet.ARP
 
senderProtocolAddress - Variable in class org.onlab.packet.ARP
 
sendMessage(ObjectNode) - Method in class org.onosproject.ui.RequestHandler
Sends a message back to the client.
sendMessage(ObjectNode) - Method in interface org.onosproject.ui.UiConnection
Sends the specified JSON message to the user interface client.
sendMessage(ObjectNode) - Method in class org.onosproject.ui.UiMessageHandler
Sends the specified data to the client.
sendMessage(String, ObjectNode) - Method in class org.onosproject.ui.RequestHandler
Sends a message back to the client with the given event type and payload.
sendMessage(String, ObjectNode) - Method in interface org.onosproject.ui.UiConnection
Composes a message into JSON and sends it to the user interface client.
sendPacketOut(ByteBuffer) - Method in interface org.onosproject.net.behaviour.upf.UpfDevice
Sends the given data as a data plane packet-out through this device.
sendThrough() - Method in class org.onosproject.net.packet.DefaultOutboundPacket
 
sendThrough() - Method in interface org.onosproject.net.packet.OutboundPacket
Returns the identity of a device through which this packet should be sent.
SEPARATOR - Static variable in interface org.onosproject.net.flow.criteria.Criterion
 
SEPARATOR - Static variable in class org.onosproject.net.flow.instructions.L1ModificationInstruction
 
SEPARATOR - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
sequence - Variable in class org.onlab.packet.ipv6.Authentication
 
sequence - Variable in class org.onlab.packet.ipv6.EncapSecurityPayload
 
sequence - Variable in class org.onlab.packet.RIPV2AuthEntry
 
sequence - Variable in class org.onlab.packet.TCP
 
serial() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device serial number.
serial(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device serial number.
SERIAL_NUMBER - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
serialize() - Method in class org.onlab.packet.ARP
 
serialize() - Method in class org.onlab.packet.bmp.Bmp
 
serialize() - Method in class org.onlab.packet.bmp.BmpPeer
 
serialize() - Method in class org.onlab.packet.Data
 
serialize() - Method in class org.onlab.packet.dhcp.CircuitId
Combines connect point with vlan id with separator ':' as circuit id.
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
serialize() - Method in class org.onlab.packet.dhcp.Dhcp6Option
 
serialize() - Method in class org.onlab.packet.dhcp.DhcpOption
 
serialize() - Method in class org.onlab.packet.dhcp.DhcpRelayAgentOption
 
serialize() - Method in class org.onlab.packet.DHCP
 
serialize() - Method in class org.onlab.packet.DHCP6
 
serialize() - Method in class org.onlab.packet.EAP
 
serialize() - Method in class org.onlab.packet.EAPOL
Serializes the packet, based on the code/type using the payload to compute its length.
serialize() - Method in class org.onlab.packet.EAPOLMkpdu
 
serialize() - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
serialize() - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
serialize() - Method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
 
serialize() - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
serialize() - Method in interface org.onlab.packet.EAPOLMkpduParameterSet
Utility function for Serializing Parameter Set.
serialize() - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
 
serialize() - Method in class org.onlab.packet.Ethernet
 
serialize() - Method in class org.onlab.packet.ICMP
Serializes the packet.
serialize() - Method in class org.onlab.packet.ICMP6
 
serialize() - Method in class org.onlab.packet.ICMPEcho
Serializes the packet.
serialize() - Method in class org.onlab.packet.IGMP
Serialize this IGMP packet.
serialize() - Method in interface org.onlab.packet.IPacket
Sets all payloads parent packet if applicable, then serializes this packet and all payloads.
serialize() - Method in class org.onlab.packet.IPv4
Serializes the packet.
serialize() - Method in class org.onlab.packet.ipv6.Authentication
 
serialize() - Method in class org.onlab.packet.ipv6.BaseOptions
 
serialize() - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
 
serialize() - Method in class org.onlab.packet.ipv6.Fragment
 
serialize() - Method in class org.onlab.packet.ipv6.Routing
 
serialize() - Method in class org.onlab.packet.IPv6
 
serialize() - Method in class org.onlab.packet.lacp.Lacp
 
serialize() - Method in class org.onlab.packet.lacp.LacpBaseTlv
 
serialize() - Method in class org.onlab.packet.lacp.LacpCollectorTlv
 
serialize() - Method in class org.onlab.packet.lacp.LacpTerminatorTlv
 
serialize() - Method in class org.onlab.packet.LLC
 
serialize() - Method in class org.onlab.packet.LLDP
 
serialize() - Method in class org.onlab.packet.LLDPOrganizationalTLV
 
serialize() - Method in class org.onlab.packet.LLDPTLV
 
serialize() - Method in class org.onlab.packet.MPLS
 
serialize() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
 
serialize() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
serialize() - Method in class org.onlab.packet.ndp.NeighborSolicitation
 
serialize() - Method in class org.onlab.packet.ndp.Redirect
 
serialize() - Method in class org.onlab.packet.ndp.RouterAdvertisement
 
serialize() - Method in class org.onlab.packet.ndp.RouterSolicitation
 
serialize() - Method in class org.onlab.packet.pim.PIMAddrGroup
Serialize this group address.
serialize() - Method in class org.onlab.packet.pim.PIMAddrSource
 
serialize() - Method in class org.onlab.packet.pim.PIMAddrUnicast
 
serialize() - Method in class org.onlab.packet.pim.PIMHello
Sets all payloads parent packet if applicable, then serializes this packet and all payloads.
serialize() - Method in class org.onlab.packet.pim.PIMHelloOption
 
serialize() - Method in class org.onlab.packet.pim.PIMJoinPrune
Sets all payloads parent packet if applicable, then serializes this packet and all payloads.
serialize() - Method in class org.onlab.packet.PIM
Serializes the packet.
serialize() - Method in class org.onlab.packet.PPPoED
 
serialize() - Method in class org.onlab.packet.RADIUS
 
serialize() - Method in class org.onlab.packet.RIP
 
serialize() - Method in class org.onlab.packet.RIPng
 
serialize() - Method in class org.onlab.packet.RIPngEntry
 
serialize() - Method in class org.onlab.packet.RIPV2AuthEntry
 
serialize() - Method in class org.onlab.packet.RIPV2Entry
 
serialize() - Method in class org.onlab.packet.Slow
 
serialize() - Method in class org.onlab.packet.TCP
Serializes the packet.
serialize() - Method in class org.onlab.packet.UDP
Serializes the packet.
serialize() - Method in class org.onlab.packet.VXLAN
Serializes the packet.
serialize() - Method in class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
 
serialize() - Method in interface org.onosproject.net.flow.Extension
Serialize the extension to a byte array.
serialize() - Method in class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
 
serialize(Object) - Method in class org.onlab.util.KryoNamespace
Serializes given object to byte array using Kryo instance in pool.
serialize(Object, int) - Method in class org.onlab.util.KryoNamespace
Serializes given object to byte array using Kryo instance in pool.
serialize(Object, OutputStream) - Method in class org.onlab.util.KryoNamespace
Serializes given object to OutputStream using Kryo instance in pool.
serialize(Object, OutputStream, int) - Method in class org.onlab.util.KryoNamespace
Serializes given object to OutputStream using Kryo instance in pool.
serialize(Object, ByteBuffer) - Method in class org.onlab.util.KryoNamespace
Serializes given object to byte buffer using Kryo instance in pool.
serialize(ByteBuffer) - Method in class org.onlab.packet.IGMPGroup
Serialize the IGMPGroup subclass.
serialize(ByteBuffer) - Method in class org.onlab.packet.IGMPMembership
Serialize this Membership Report.
serialize(ByteBuffer) - Method in class org.onlab.packet.IGMPQuery
Serialize this IGMPQuery.
serializer() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns the serializer.
Serializer - Interface in org.onosproject.store.service
Interface for serialization of store artifacts.
serialNumber() - Method in class org.onosproject.net.DefaultDevice
 
serialNumber() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
serialNumber() - Method in interface org.onosproject.net.device.DeviceDescription
Returns the device serial number.
serialNumber() - Method in interface org.onosproject.net.Device
Returns the device serial number.
serialNumber() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
seriesCount() - Method in class org.onosproject.ui.chart.ChartModel
Returns the number of series in this chart model.
SERVER - org.onosproject.net.Device.Type
 
SERVER_ID_OVERRIDE - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
ServerErrorMapper - Class in org.onlab.rest.exceptions
Mapper for service not found exceptions to the INTERNAL_SERVER_ERROR response code.
ServerErrorMapper() - Constructor for class org.onlab.rest.exceptions.ServerErrorMapper
 
SERVERID - org.onlab.packet.DHCP6.OptionCode
 
serverIPAddress - Variable in class org.onlab.packet.DHCP
 
serverName - Variable in class org.onlab.packet.DHCP
 
servers() - Method in class org.onosproject.store.service.PartitionClientInfo
Returns the collection of servers that are members of the partition.
service - Variable in class org.onosproject.cli.net.TopologyCommand
 
service - Variable in class org.onosproject.rest.AbstractApiDocRegistrator
 
SERVICE_DISRUPTED - org.onosproject.cluster.LeadershipEvent.Type
Signifies the Leadership Elector is unavailable.
SERVICE_RESTORED - org.onosproject.cluster.LeadershipEvent.Type
Signifies the Leadership Elector is available again.
serviceAffecting() - Method in interface org.onosproject.alarm.Alarm
Returns true if alarm is service affecting Note: Whilst X.733 combines service-affecting state with severity (where severities of critical and major are deemed service-affecting) ONOS keeps these attributes separate.
serviceAffecting() - Method in class org.onosproject.alarm.DefaultAlarm
 
ServiceBundle - Interface in org.onosproject.ui.model
A bundle of services to pass to elements that might need a reference to them.
serviceDirectory - Static variable in class org.onosproject.net.driver.DefaultDriverHandler
 
serviceDirectory - Static variable in class org.onosproject.security.SecurityUtil
 
ServiceDirectory - Interface in org.onlab.osgi
Simple abstraction of a service directory where service implementations can be found by the class name of the interfaces they provide.
serviceIndex() - Method in class org.onosproject.net.NshServiceIndex
Returns nsh service index value.
ServiceNotFoundException - Exception in org.onlab.osgi
Represents condition where some service is not found or not available.
ServiceNotFoundException() - Constructor for exception org.onlab.osgi.ServiceNotFoundException
Creates a new exception with no message.
ServiceNotFoundException(String) - Constructor for exception org.onlab.osgi.ServiceNotFoundException
Creates a new exception with the supplied message.
ServiceNotFoundException(String, Throwable) - Constructor for exception org.onlab.osgi.ServiceNotFoundException
Creates a new exception with the supplied message and cause.
ServiceNotFoundMapper - Class in org.onlab.rest.exceptions
Mapper for service not found exceptions to the SERVICE_UNAVAILABLE response code.
ServiceNotFoundMapper() - Constructor for class org.onlab.rest.exceptions.ServiceNotFoundMapper
 
servicePathId() - Method in class org.onosproject.net.NshServicePathId
Returns nsh context service path identifier.
session - Variable in class org.onosproject.cli.AbstractChoicesCompleter
 
sessionId - Variable in class org.onlab.packet.PPPoED
 
sessionId() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Get the ID of the PFCP Session that produced this FAR.
sessionId() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Get the ID of the PFCP session that produced this PDR.
sessionId() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
Returns the identifier of this clone session, unique in the scope of a PRE instance.
sessionId() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
Returns the clone session ID associated with this handle.
set(boolean) - Method in class org.onlab.util.BlockingBoolean
Sets the value of the blocking boolean.
set(long) - Method in class org.onosproject.store.primitives.DefaultAtomicCounter
 
set(long) - Method in interface org.onosproject.store.service.AsyncAtomicCounter
Atomically sets the given value to the current value.
set(long) - Method in interface org.onosproject.store.service.AtomicCounter
Atomically sets the given value to the current value.
set(String, String) - Method in class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
 
set(String, String) - Method in class org.onosproject.net.DefaultAnnotations.Builder
Adds the specified annotation.
set(String, String) - Method in class org.onosproject.net.driver.DefaultDriverData
 
set(String, String) - Method in interface org.onosproject.net.MutableAnnotations
Returns the value of the specified annotation.
set(DocumentPath, V) - Method in class org.onosproject.store.primitives.DefaultDocumentTree
 
set(DocumentPath, V) - Method in interface org.onosproject.store.service.AsyncDocumentTree
Creates or updates a document tree node.
set(DocumentPath, V) - Method in interface org.onosproject.store.service.DocumentTree
Creates or updates a document tree node.
set(V) - Method in class org.onosproject.store.primitives.DefaultAtomicValue
 
set(V) - Method in interface org.onosproject.store.service.AsyncAtomicValue
Sets to the given value.
set(V) - Method in interface org.onosproject.store.service.AtomicValue
Sets to the given value.
SET - org.onosproject.net.group.GroupStore.UpdateType
Modify existing group entry by setting the provided information, overwriting the previous group entry entirely.
SET - org.onosproject.store.service.DistributedPrimitive.Type
Distributed set.
setAccess() - Method in class org.onosproject.net.behaviour.upf.UpfInterface.Builder
Make this an access-facing interface.
setAcknowledge(int) - Method in class org.onlab.packet.TCP
Sets acknowledge number.
setActive(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets active bit.
setActive(String) - Method in class org.onosproject.common.app.ApplicationArchive
Marks the app as active by creating token file in the app directory.
setActorMI(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set Member Identifier.
setActorMN(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set Member Identifier.
setActorMN(int) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set Member Identifier.
setAdddress(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
To set address.
setAddr(String) - Method in class org.onlab.packet.pim.PIMAddrGroup
PIM encoded source address.
setAddr(String) - Method in class org.onlab.packet.pim.PIMAddrSource
PIM Encoded Source Address.
setAddr(IpAddress) - Method in class org.onlab.packet.pim.PIMAddrUnicast
PIM Encoded Source Address.
setAddr(IpPrefix) - Method in class org.onlab.packet.pim.PIMAddrGroup
Set the encoded source address.
setAddr(IpPrefix) - Method in class org.onlab.packet.pim.PIMAddrSource
PIM Encoded Source Address.
setAddress(Ip4Address) - Method in class org.onosproject.net.behaviour.upf.UpfInterface.Builder
Set the IPv4 prefix of this interface, by turning the given address into a /32 prefix.
setAddressFamilyId(short) - Method in class org.onlab.packet.RIPV2AuthEntry
 
setAddressFamilyId(short) - Method in class org.onlab.packet.RIPV2Entry
 
setAggregatable(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets aggregatable bit.
setAlgAgility(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set Algorithm Agility.
setAnnotations(Annotations) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the annotations.
setArpOp(short) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setArpOp(short) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the arp operation.
setArpSha(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setArpSha(MacAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the arp src mac address.
setArpSpa(IpAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setArpSpa(IpAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the arp src ip address.
setArpTha(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setArpTha(MacAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the arp dst mac address.
setArpTpa(IpAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setArpTpa(IpAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the arp dst ip address.
setAttribute(byte, byte[]) - Method in class org.onlab.packet.RADIUS
Sets an attribute in the RADIUS packet.
setAuthenticator(byte[]) - Method in class org.onlab.packet.RADIUS
Sets the authenticator.
setAuthLen(byte) - Method in class org.onlab.packet.RIPV2AuthEntry
 
setAuxLocations(Set<HostLocation>) - Method in class org.onosproject.net.config.basics.BasicHostConfig
Sets the auxLocations of the host.
setBadge(NodeBadge) - Method in class org.onosproject.ui.topo.NodeHighlight
Sets the badge for this node.
setBodyLength(short) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set body length.
setBodyLength(short) - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
setBodyLength(short) - Method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
To set body length.
setBodyLength(short) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
setBodyLength(short) - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
Body Length.
setBootFileName(String) - Method in class org.onlab.packet.DHCP
 
setBucketsForGroup(DeviceId, GroupKey, GroupBuckets, GroupKey, ApplicationId) - Method in interface org.onosproject.net.group.GroupService
Set buckets for an existing group.
setBufferFlag(boolean) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Make this FAR buffer incoming packets.
setBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new DistributedSetBuilder.
setBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new DistributedSetBuilder.
setBytes(long) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setBytes(long) - Method in interface org.onosproject.net.flow.StoredFlowEntry
Number of bytes seen by this rule.
setBytes(long) - Method in class org.onosproject.net.group.DefaultGroup
Sets number of bytes processed by this group entry.
setBytes(long) - Method in class org.onosproject.net.group.DefaultGroupBucket
 
setBytes(long) - Method in interface org.onosproject.net.group.StoredGroupBucketEntry
Sets number of bytes processed by this group bucket entry.
setBytes(long) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets number of bytes processed by this group entry.
setBytes(long) - Method in interface org.onosproject.net.meter.BandEntry
Sets the number of bytes seen by this band.
setBytes(long) - Method in class org.onosproject.net.meter.DefaultBand
 
setBytesReceived(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of received bytes.
setBytesSent(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of sent bytes.
setChassisId(ChassisId) - Method in class org.onlab.packet.ONOSLLDP
 
setChassisId(LLDPTLV) - Method in class org.onlab.packet.LLDP
 
setChecksum(short) - Method in class org.onlab.packet.ICMP
 
setChecksum(short) - Method in class org.onlab.packet.ICMP6
Sets checksum.
setChecksum(short) - Method in class org.onlab.packet.IPv4
 
setChecksum(short) - Method in class org.onlab.packet.PIM
Set the checksum.
setChecksum(short) - Method in class org.onlab.packet.TCP
Sets checksum.
setChecksum(short) - Method in class org.onlab.packet.UDP
 
setChildren(Set<RegionId>) - Method in class org.onosproject.ui.model.topo.UiRegion
Sets the children IDs for this region.
setCKN(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set CAK name.
setClientHardwareAddress(byte[]) - Method in class org.onlab.packet.DHCP
 
setClientIPAddress(int) - Method in class org.onlab.packet.DHCP
 
setClt(int) - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
Sets Identity Association ID.
setClusterMetadata(ClusterMetadata) - Method in interface org.onosproject.cluster.ClusterMetadataAdminService
Updates the cluster metadata.
setClusterMetadata(ClusterMetadata) - Method in interface org.onosproject.cluster.ClusterMetadataProvider
Updates cluster metadata.
setCmdType(byte) - Method in class org.onlab.packet.RIP
 
setCmdType(byte) - Method in class org.onlab.packet.RIPng
 
setCode(byte) - Method in class org.onlab.packet.dhcp.DhcpOption
 
setCode(byte) - Method in class org.onlab.packet.EAP
Sets the EAP code.
setCode(byte) - Method in class org.onlab.packet.PPPoED
 
setCode(byte) - Method in class org.onlab.packet.RADIUS
Sets the code.
setCode(short) - Method in class org.onlab.packet.dhcp.Dhcp6Option
Sets the code of this option.
setCollecting(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets collecting bit.
setCollectorIp(IpAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets the collector IP to the config.
setCollectorMaxDelay(short) - Method in class org.onlab.packet.lacp.LacpCollectorTlv
Sets collector max delay.
setCollectorNextHopMac(MacAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets collector next hop mac address to the config.
setCollectorPort(TpPort) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets the collector port to the config.
setComparator(String, CellComparator) - Method in class org.onosproject.ui.table.TableModel
Sets a cell comparator for the specified column.
setCompatible(boolean) - Method in class org.onlab.util.KryoNamespace.Builder
Sets whether backwards/forwards compatible versioned serialization is enabled.
setConfidentialityOffset(byte) - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
setConfiguration(String) - Method in interface org.onosproject.net.behaviour.ConfigSetter
Sets the configuration contained in the file at the file path, returns the response of the device.
setControllers(List<ControllerInfo>) - Method in interface org.onosproject.net.behaviour.ControllerConfig
Set a list of controllers on a device.
setCore() - Method in class org.onosproject.net.behaviour.upf.UpfInterface.Builder
Make this a core-facing interface.
setCoreService(CoreService) - Static method in class org.onosproject.net.config.basics.SubjectFactories
Provides reference to the core service, which is required for application subject factory.
setCost(Weight) - Method in class org.onlab.graph.DefaultMutablePath
 
setCost(Weight) - Method in interface org.onlab.graph.MutablePath
Sets the total path cost as a weight object.
setCtrl(byte) - Method in class org.onlab.packet.LLC
 
setCurrentHopLimit(byte) - Method in class org.onlab.packet.ndp.RouterAdvertisement
Sets current hop limit.
setCurrentLayout(UiTopoLayout) - Method in interface org.onosproject.ui.UiConnection
Changes the current layout context to the specified layout.
setCurrentView(String) - Method in interface org.onosproject.ui.UiConnection
Sets the currently selected view.
setData(byte[]) - Method in class org.onlab.packet.Data
 
setData(byte[]) - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
setData(byte[]) - Method in class org.onlab.packet.dhcp.Dhcp6Option
Sets the data of this option.
setData(byte[]) - Method in class org.onlab.packet.dhcp.DhcpOption
 
setData(byte[]) - Method in class org.onlab.packet.EAP
Sets the EAP data.
setData(DriverData) - Method in class org.onosproject.net.driver.AbstractBehaviour
 
setData(DriverData) - Method in interface org.onosproject.net.driver.Behaviour
Sets the driver data context on this this behaviour should operate.
setDataOffset(byte) - Method in class org.onlab.packet.TCP
Sets offset.
setDataType(byte) - Method in class org.onlab.packet.EAP
Sets the data type.
setDbufReceiver() - Method in class org.onosproject.net.behaviour.upf.UpfInterface.Builder
Make this a dbuf-facing interface.
setDefault(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets default bit.
setDefaultGraphPathSearch(GraphPathSearch<TopologyVertex, TopologyEdge>) - Static method in class org.onosproject.common.DefaultTopology
Sets the default lpath search algorighm to be used when computing paths.
setDefaultGraphPathSearch(GraphPathSearch<TopologyVertex, TopologyEdge>) - Method in interface org.onosproject.net.topology.PathAdminService
Sets the specified graph path search algorightm to be used as a default.
setDefaultLinkWeigher(LinkWeigher) - Static method in class org.onosproject.common.DefaultTopology
Sets the default link-weight to be used when computing paths.
setDefaultLinkWeigher(LinkWeigher) - Method in interface org.onosproject.net.topology.PathAdminService
Sets the specified link-weight function to be used as a default.
setDefaultMaxPaths(int) - Static method in class org.onosproject.common.DefaultTopology
Sets the default maximum path count to be used when computing paths.
setDefaultMaxPaths(int) - Method in interface org.onosproject.net.topology.PathAdminService
Sets the default maximum path count to be used when computing paths.
setDefaultTimeoutForPurge(int) - Method in interface org.onosproject.dhcp.DhcpStore
Sets the default time for which suggested IP mappings are valid.
setDelayProtect(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
To set Delay Protect.
setDelegate(D) - Method in class org.onosproject.store.AbstractStore
 
setDelegate(D) - Method in interface org.onosproject.store.Store
Sets the delegate on the store.
setDelegate(ApplicationStoreDelegate) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
setDelegate(TopologyChangeDelegate) - Method in interface org.onosproject.net.intent.ObjectiveTrackerService
Sets a topology change delegate.
setDestinationAddress(byte[]) - Method in class org.onlab.packet.IPv6
Sets destination address.
setDestinationAddress(byte[]) - Method in class org.onlab.packet.ndp.Redirect
Sets destination address.
setDestinationAddress(int) - Method in class org.onlab.packet.IPv4
 
setDestinationAddress(String) - Method in class org.onlab.packet.IPv4
 
setDestinationMACAddress(byte[]) - Method in class org.onlab.packet.Ethernet
Sets the destination MAC address.
setDestinationMACAddress(String) - Method in class org.onlab.packet.Ethernet
Sets the destination MAC address.
setDestinationMACAddress(MacAddress) - Method in class org.onlab.packet.Ethernet
Sets the destination MAC address.
setDestinationPort(int) - Method in class org.onlab.packet.TCP
Sets TCP destination port.
setDestinationPort(int) - Method in class org.onlab.packet.UDP
 
setDevice(String) - Method in class org.onlab.packet.ONOSLLDP
 
setDeviceId(DeviceId) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the device identifier.
setDiffServ(byte) - Method in class org.onlab.packet.IPv4
Sets the DiffServ octet (including the DSCP and ECN bits).
setDispatchTimeLimit(long) - Method in interface org.onosproject.event.EventDeliveryService
Sets the number of millis that an event sink has to process an event.
setDistributedAN(byte) - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
setDistributing(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets distributing bit.
setDomainInfo(String) - Method in class org.onlab.packet.ONOSLLDP
 
setDriverService(Object, DriverService) - Static method in class org.onosproject.net.AbstractProjectableModel
Injects the driver service reference for use during projections into various behaviours.
setDropFlag(boolean) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Make this FAR drop incoming packets.
setDsap(byte) - Method in class org.onlab.packet.LLC
 
setDscp(byte) - Method in class org.onlab.packet.IPv4
Sets the DSCP value (6 bits).
setDst(Ip4Address) - Method in class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
Set the destination IP address of the unidirectional GTP tunnel.
setDuid(Dhcp6Duid) - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
setDuidTime(int) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setDuidType(Dhcp6Duid.DuidType) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setDurationNano(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the time port has been alive in nano seconds.
setDurationSec(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the time port has been alive in seconds.
setEapolType(byte) - Method in class org.onlab.packet.EAPOL
Sets the EAPOL type.
setEcn(byte) - Method in class org.onlab.packet.IPv4
Sets the ECN value (2 bits).
setEdgeLinkId(UiLinkId) - Method in class org.onosproject.ui.model.topo.UiHost
Sets the ID of the edge link between this host and the device to which it connects.
setEgress(long, long) - Method in class org.onosproject.net.behaviour.upf.PdrStats.Builder
Set the number of packets and bytes that hit the PDR counter in the dataplane egress pipeline.
setEgressInnerVlan(VlanId) - Method in class org.onosproject.net.config.basics.McastConfig
Sets egress inner VLAN of multicast traffic.
setEgressPacket(PipelineTraceablePacket) - Method in class org.onosproject.net.PipelineTraceableHitChain
Sets the egress packet.
setEgressVlan(VlanId) - Method in class org.onosproject.net.config.basics.McastConfig
Sets egress VLAN of multicast traffic.
setEnabled(String) - Method in class org.onosproject.net.config.basics.HostLearningConfig
 
setEnterpriseNumber(int) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setEntirePollInterval(long) - Method in class org.onosproject.net.statistic.PollInterval
Sets the entire poll interval in seconds.
setErrorCount(int) - Method in class org.onosproject.net.intent.IntentData
Sets the error count for this intent.
setEthDst(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setEthDst(MacAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the dst l2 address.
setEtherType(short) - Method in class org.onlab.packet.Ethernet
Sets the Ethernet type.
setEthSrc(MacAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setEthSrc(MacAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the src l2 address.
SetEvent<E> - Class in org.onosproject.store.service
Representation of a DistributedSet update notification.
SetEvent(String, SetEvent.Type, E) - Constructor for class org.onosproject.store.service.SetEvent
Creates a new event object.
SetEvent.Type - Enum in org.onosproject.store.service
SetEvent type.
SetEventListener<E> - Interface in org.onosproject.store.service
Listener to be notified about updates to a DistributedSet.
setExpired(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets expired bit.
setFailedRetryCount(int) - Method in class org.onosproject.net.group.DefaultGroup
 
setFailedRetryCount(int) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets the count for the number of failed attempts in programming this group.
setFarId(int) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set the PFCP Session-local ID of this FAR.
setField(T, String, U) - Static method in class org.onlab.junit.TestUtils
Sets the field, bypassing scope restriction.
setFlag(byte) - Method in class org.onlab.packet.VXLAN
Set flags.
setFlags(byte) - Method in class org.onlab.packet.IPv4
 
setFlags(short) - Method in class org.onlab.packet.DHCP
 
setFlags(short) - Method in class org.onlab.packet.TCP
Sets TCP flags.
setFlowLabel(int) - Method in class org.onlab.packet.IPv6
Sets flow label.
setFlowLiveType(TypedStoredFlowEntry.FlowLiveType) - Method in class org.onosproject.net.flow.DefaultTypedFlowEntry
 
setFlowLiveType(TypedStoredFlowEntry.FlowLiveType) - Method in interface org.onosproject.net.flow.TypedStoredFlowEntry
Sets the new flow live type for this entry.
setFormatter(String, CellFormatter) - Method in class org.onosproject.ui.table.TableModel
Sets a cell formatter for the specified column.
setForwardFlag(boolean) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Make this FAR forward incoming packets.
setFragmentOffset(short) - Method in class org.onlab.packet.IPv4
 
setFragmentOffset(short) - Method in class org.onlab.packet.ipv6.Fragment
Sets the fragment offset of this header.
setFree(long) - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
Set free memory of device.
setGatewayIPAddress(int) - Method in class org.onlab.packet.DHCP
 
setGroup(IpPrefix) - Method in class org.onlab.packet.pim.PIMJoinPruneGroup
 
setGuardTime(int) - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
setGuardTime(int) - Method in interface org.onosproject.net.packet.PacketInFilter
Set the Guard time in case WinThres is crossed.
setHandler(DriverHandler) - Method in class org.onosproject.net.driver.AbstractHandlerBehaviour
 
setHandler(DriverHandler) - Method in interface org.onosproject.net.driver.HandlerBehaviour
Sets the driver handler context for this behaviour.
setHardwareAddressLength(byte) - Method in class org.onlab.packet.ARP
 
setHardwareAddressLength(byte) - Method in class org.onlab.packet.DHCP
 
setHardwareType(byte) - Method in class org.onlab.packet.DHCP
 
setHardwareType(short) - Method in class org.onlab.packet.ARP
 
setHardwareType(short) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setHeaderExtLength(byte) - Method in class org.onlab.packet.ipv6.BaseOptions
Sets the extension length of this header.
setHeaderExtLength(byte) - Method in class org.onlab.packet.ipv6.Routing
Sets the extension length of this header.
setHoldTime(short) - Method in class org.onlab.packet.pim.PIMJoinPrune
Set the J/P holdtime in seconds.
setHopCount(byte) - Method in class org.onlab.packet.DHCP6
Sets hop count.
setHopLimit(byte) - Method in class org.onlab.packet.IPv6
Sets hop limit.
setHops(byte) - Method in class org.onlab.packet.DHCP
 
setIaId(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Sets Identity Association ID.
setIaId(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Sets Identity Association ID.
setIaId(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
Sets Identity Association ID.
setIcmpCode(byte) - Method in class org.onlab.packet.ICMP
 
setIcmpCode(byte) - Method in class org.onlab.packet.ICMP6
Sets ICMP6 code.
setIcmpType(byte) - Method in class org.onlab.packet.ICMP
 
setIcmpType(byte) - Method in class org.onlab.packet.ICMP6
Sets ICMP6 type.
setICV(byte[]) - Method in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
To set ICV.
setIdentification(int) - Method in class org.onlab.packet.ipv6.Fragment
Sets the identification of this header.
setIdentification(short) - Method in class org.onlab.packet.IPv4
 
setIdentifier(byte) - Method in class org.onlab.packet.EAP
Sets the EAP identifier.
setIdentifier(byte) - Method in class org.onlab.packet.RADIUS
Sets the identifier.
setIdentifier(byte[]) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setIdentifier(short) - Method in class org.onlab.packet.ICMPEcho
Sets the identifier.
setIgmpType(byte) - Method in class org.onlab.packet.IGMP
Set the IGMP message type.
setInfoString(byte[]) - Method in class org.onlab.packet.LLDPOrganizationalTLV
Set the value of information string.
setInfoString(String) - Method in class org.onlab.packet.LLDPOrganizationalTLV
Set the value of information string.
setIngegrityCheck(byte[]) - Method in class org.onlab.packet.ipv6.Authentication
Sets the integrity check value of this header.
setIngress(long, long) - Method in class org.onosproject.net.behaviour.upf.PdrStats.Builder
Set the number of packets and bytes that hit the PDR counter in the dataplane ingress pipeline.
setIngressVlan(VlanId) - Method in class org.onosproject.net.config.basics.McastConfig
Sets ingress VLAN of multicast traffic.
setInnerVlan(VlanId) - Method in class org.onosproject.net.config.basics.BasicHostConfig
 
setInPort(byte[]) - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Sets inPort string.
setIp6Address(Ip6Address) - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Sets IPv6 address.
setIp6Prefix(Ip6Address) - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Sets IPv6 prefix.
setIpAddress(Ip4Address) - Method in class org.onlab.packet.RIPV2Entry
 
setIpDscp(byte) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setIpDscp(byte) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the IP DSCP field.
setIpDst(IpAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setIpDst(IpAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the dst l3 address.
setIps(Set<IpAddress>) - Method in class org.onosproject.net.config.basics.BasicHostConfig
Sets the IP addresses of the host.
setIpSrc(IpAddress) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setIpSrc(IpAddress) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the src l3 address.
setIsGroupStateAddedFirstTime(boolean) - Method in class org.onosproject.net.group.DefaultGroup
 
setIsGroupStateAddedFirstTime(boolean) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets if group has transitioned to ADDED state for the first time.
setIsRouter(boolean) - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Sets whether this neighbour message context involves a router.
setKey(short) - Method in class org.onlab.packet.lacp.LacpBaseTlv
Sets key.
setKeyId(byte) - Method in class org.onlab.packet.RIPV2AuthEntry
 
setKeyNumber(int) - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
setKeyServer(boolean) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set Key Server.
setKeyServerPriority(byte) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set Key Server Priority.
setKeyWrapper(EAPOLMkpduDistributedSAKParameterSet.KeyWrapper) - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
setLabel(int) - Method in class org.onlab.packet.MPLS
Sets the MPLS label.
setLabel(String) - Method in class org.onosproject.ui.topo.LinkHighlight
Adds a label to be displayed on the link.
setLacpVersion(byte) - Method in class org.onlab.packet.lacp.Lacp
Sets LACP version.
setLastSeen() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setLastSeen() - Method in interface org.onosproject.net.flow.StoredFlowEntry
Sets the last active epoch time.
setLatestAN(byte) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Latest Key Server Association Number.
setLatestKI(byte[]) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Latest Key Server Identifier.
setLatestKN(int) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Latest Key Server Key Number.
setLatestLAPN(int) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Lowest Acceptable Packet Number for Latest Key Server.
setLatestRX(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Latest Key Server used for RX protection .
setLatestTX(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Latest Key Server used for TX protection.
setLayer(String) - Method in class org.onosproject.ui.model.topo.UiNode
Sets this node's "layer", for layered rendering.
setLayerOrder(String...) - Method in class org.onosproject.ui.model.topo.UiRegion
Sets the layer order for this region.
setLength(byte) - Method in class org.onlab.packet.dhcp.DhcpOption
 
setLength(byte) - Method in class org.onlab.packet.RADIUSAttribute
Sets the attribute length.
setLength(int) - Method in class org.onlab.packet.bmp.Bmp
Sets message length.
setLength(short) - Method in class org.onlab.packet.dhcp.Dhcp6Option
Sets length of this option.
setLength(short) - Method in class org.onlab.packet.EAP
Sets the packet length.
setLength(short) - Method in class org.onlab.packet.LLDPTLV
 
setLength(short) - Method in class org.onlab.packet.PPPoEDTag
 
setLife(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
setLife(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerEntry
Set the amount of time the policer has existed in seconds.
setLife(long) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setLife(long) - Method in interface org.onosproject.net.flow.StoredFlowEntry
Sets how long this entry has been entered in the system.
setLife(long) - Method in class org.onosproject.net.group.DefaultGroup
Sets how long this entry has been entered in the system.
setLife(long) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets how long this entry has been entered in the system.
setLife(long) - Method in class org.onosproject.net.meter.DefaultMeter
 
setLife(long) - Method in interface org.onosproject.net.meter.MeterEntry
Set the amount of time the meter has existed in seconds.
setLife(long, TimeUnit) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setLife(long, TimeUnit) - Method in interface org.onosproject.net.flow.StoredFlowEntry
Sets how long this entry has been entered in the system.
setLinkAddress(byte[]) - Method in class org.onlab.packet.DHCP6
Sets link address.
setLinkLayerAddress(byte[]) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setList(String, Function<? super T, String>, List<T>) - Method in class org.onosproject.net.config.Config
Sets the specified property as an array of items in a given collection transformed into a String with supplied function.
setLiveType(FlowEntry.FlowLiveType) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setLiveType(FlowEntry.FlowLiveType) - Method in interface org.onosproject.net.flow.StoredFlowEntry
Sets the flow live type, i.e., IMMEDIATE, SHORT, MID, LONG.
setLocation(DeviceId, PortNumber) - Method in class org.onosproject.ui.model.topo.UiHost
Sets the host's current location.
setLocations(Set<HostLocation>) - Method in class org.onosproject.net.config.basics.BasicHostConfig
Sets the location of the host.
setLongPollInterval(long) - Method in class org.onosproject.net.statistic.PollInterval
Sets the long poll interval in seconds.
setMacAddress(MacAddress) - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Sets MacAddress address.
setMacSecCapability(byte) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set MACSec Capacity.
setMacSecDesired(boolean) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set MACSec Desired.
setMaster(NodeId, DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Sets a device's role for a specified controller instance.
setMaxRespCode(byte) - Method in class org.onlab.packet.IGMP.IGMPv2
 
setMaxRespCode(byte) - Method in class org.onlab.packet.IGMP.IGMPv3
 
setMaxRespCode(byte) - Method in class org.onlab.packet.IGMP
Set the Max Resp Code.
setMetric(int) - Method in class org.onlab.packet.RIPngEntry
 
setMetric(int) - Method in class org.onlab.packet.RIPV2Entry
 
setMetricsService(MetricsService) - Static method in class org.onlab.util.SharedExecutors
Enables or disables calculation of the pool performance metrics.
setMFlag(byte) - Method in class org.onlab.packet.ndp.RouterAdvertisement
Sets managed address configuration flag.
setMidPollInterval(long) - Method in class org.onosproject.net.statistic.PollInterval
Sets the mid poll interval in seconds.
setMinFlowHopLatencyChangeNs(int) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets the minimal interval of hop latency change for a flow to the config.
setMkaVersion(byte) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set MKA Version.
setModulationScheme(PortNumber, T, long) - Method in interface org.onosproject.net.behaviour.ModulationConfig
Set the target Modulation Scheme on the component.
setMoreFragment(byte) - Method in class org.onlab.packet.ipv6.Fragment
Sets the more fragment flag of this header.
setMpls(MplsLabel) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setMpls(MplsLabel) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the mpls label.
setMplsBos(boolean) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setMplsBos(boolean) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the mpls bottom-of-stack indicator bit.
setMsgType(byte) - Method in class org.onlab.packet.DHCP6
Sets message type.
setName(String) - Method in class org.onlab.packet.ONOSLLDP
 
setNextHeader(byte) - Method in class org.onlab.packet.ipv6.Authentication
 
setNextHeader(byte) - Method in class org.onlab.packet.ipv6.BaseOptions
 
setNextHeader(byte) - Method in class org.onlab.packet.ipv6.Fragment
 
setNextHeader(byte) - Method in interface org.onlab.packet.ipv6.IExtensionHeader
Sets the type of next header.
setNextHeader(byte) - Method in class org.onlab.packet.ipv6.Routing
 
setNextHeader(byte) - Method in class org.onlab.packet.IPv6
 
setNextHop(Ip4Address) - Method in class org.onlab.packet.RIPV2Entry
 
setNotifyFlag(boolean) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set a flag specifying if the control plane should be notified when this FAR is hit.
setOffset(short) - Method in class org.onlab.packet.RIPV2AuthEntry
 
setOFlag(byte) - Method in class org.onlab.packet.ndp.RouterAdvertisement
Sets other configuration flag.
setOldAN(byte) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Old Key Server Association Number.
setOldKI(byte[]) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Old Key Server Identifier.
setOldKN(int) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Old Key Server Number.
setOldLAPN(int) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Lowest Acceptable Packet Number for Old Key Server.
setOldRX(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Old Key Server used for RX protection.
setOldTX(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Old Key Server used for TX protection.
setOpCode(byte) - Method in class org.onlab.packet.DHCP
 
setOpCode(short) - Method in class org.onlab.packet.ARP
 
setOptionalTLVList(List<LLDPTLV>) - Method in class org.onlab.packet.LLDP
 
setOptions(byte[]) - Method in class org.onlab.packet.IPv4
 
setOptions(byte[]) - Method in class org.onlab.packet.ipv6.BaseOptions
Sets the options.
setOptions(byte[]) - Method in class org.onlab.packet.TCP
Sets TCP options.
setOptions(List<Dhcp6Option>) - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Sets sub-options.
setOptions(List<Dhcp6Option>) - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Sets sub-options.
setOptions(List<Dhcp6Option>) - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
Sets sub-options.
setOptions(List<Dhcp6Option>) - Method in class org.onlab.packet.DHCP6
Sets options.
setOptions(List<DhcpOption>) - Method in class org.onlab.packet.DHCP
 
setOptions(IPacket) - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Sets options data.
setOptions(IPacket) - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Sets options data.
setOptLength(short) - Method in class org.onlab.packet.pim.PIMHelloOption
 
setOptType(short) - Method in class org.onlab.packet.pim.PIMHelloOption
 
setOrClear(String, E) - Method in class org.onosproject.net.config.Config
Sets the specified property as a double or clears it if null value given.
setOrClear(String, Boolean) - Method in class org.onosproject.net.config.Config
Sets the specified property as a boolean or clears it if null value given.
setOrClear(String, Double) - Method in class org.onosproject.net.config.Config
Sets the specified property as a double or clears it if null value given.
setOrClear(String, Integer) - Method in class org.onosproject.net.config.Config
Sets the specified property as an integer or clears it if null value given.
setOrClear(String, Long) - Method in class org.onosproject.net.config.Config
Sets the specified property as a long or clears it if null value given.
setOrClear(String, String) - Method in class org.onosproject.net.config.Config
Sets the specified property as a string or clears it if null value given.
setOrClear(String, Collection<T>) - Method in class org.onosproject.net.config.Config
Sets the specified property as an array of items in a given collection or clears it if null is given.
setOther(Link) - Method in class org.onosproject.ui.topo.BiLink
Sets the second link for this bi-link.
setOUI(byte[]) - Method in class org.onlab.packet.LLDPOrganizationalTLV
Set the value of OUI.
setOuterTpid(EthType) - Method in class org.onosproject.net.config.basics.BasicHostConfig
 
setOutput(PortNumber) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setOutput(PortNumber) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Set the output port.
setOutputPort(ConnectPoint) - Method in class org.onosproject.net.PipelineTraceableHitChain
Sets the output port.
setOverrideFlag(byte) - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Sets override flag.
setPacketLength(short) - Method in class org.onlab.packet.EAPOL
Sets the packet length.
setPackets(long) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setPackets(long) - Method in interface org.onosproject.net.flow.StoredFlowEntry
Number of packets seen by this entry.
setPackets(long) - Method in class org.onosproject.net.group.DefaultGroup
Sets number of packets processed by this group entry.
setPackets(long) - Method in class org.onosproject.net.group.DefaultGroupBucket
 
setPackets(long) - Method in interface org.onosproject.net.group.StoredGroupBucketEntry
Sets number of packets processed by this group bucket entry.
setPackets(long) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets number of packets processed by this group entry.
setPackets(long) - Method in interface org.onosproject.net.meter.BandEntry
Sets the number of packets seen by this band.
setPackets(long) - Method in class org.onosproject.net.meter.DefaultBand
 
setPacketsReceived(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of packet received.
setPacketsRxDropped(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of packets dropped by RX.
setPacketsRxErrors(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of receive errors.
setPacketsSent(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of packets sent.
setPacketsTxDropped(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of packets dropped by TX.
setPacketsTxErrors(long) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets the number of transmit errors.
setPad(boolean) - Method in class org.onlab.packet.Ethernet
Pad this packet to 60 bytes minimum, filling with zeros?
setPadding(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set padding.
setParent(IPacket) - Method in class org.onlab.packet.BasePacket
 
setParent(IPacket) - Method in interface org.onlab.packet.IPacket
Configure a new parent packet.
setParent(RegionId) - Method in class org.onosproject.ui.model.topo.UiRegion
Sets the parent ID for this region.
setPayload(IPacket) - Method in class org.onlab.packet.BasePacket
 
setPayload(IPacket) - Method in interface org.onlab.packet.IPacket
Assign the packet payload.
setPayload(IPacket) - Method in class org.onlab.packet.MPLS
 
setPayloadLength(byte) - Method in class org.onlab.packet.ipv6.Authentication
Sets the payload length of this header.
setPayloadLength(short) - Method in class org.onlab.packet.PPPoED
 
setPeerAddress(byte[]) - Method in class org.onlab.packet.DHCP6
Sets peer address.
setPeerListType(byte) - Method in class org.onlab.packet.EAPOLMkpduPeerListParameterSet
Setting List Type.
setPermissions(ApplicationId, Set<Permission>) - Method in interface org.onosproject.app.ApplicationAdminService
Updates the permissions granted to the applications.
setPermissions(ApplicationId, Set<Permission>) - Method in interface org.onosproject.app.ApplicationStore
Updates the permissions granted to the applications.
setPermissions(ApplicationId, Set<Permission>) - Method in class org.onosproject.store.app.DistributedApplicationStore
 
setPIMType(byte) - Method in class org.onlab.packet.PIM
Set the PIM message type.
setPipeconf(PiPipeconf) - Method in interface org.onosproject.net.behaviour.PiPipelineProgrammable
Writes the given pipeconf to the device, returns a completable future with true is the operations was successful, false otherwise.
setPlainRX(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
Plain RX supported or not.
setPlainTX(boolean) - Method in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
To set Plain TX supported or not.
setPollInterval(long) - Static method in class org.onosproject.net.statistic.DefaultLoad
Sets the poll interval in seconds.
setPollInterval(long) - Method in class org.onosproject.net.statistic.PollInterval
Sets the poll interval in seconds.
setPoolSize(int) - Static method in class org.onlab.util.SharedExecutors
Sets the shared thread pool size.
setPoolSize(int) - Static method in class org.onlab.util.SharedScheduledExecutors
Configures the shared scheduled thread pool size.
setPort(short) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
TO set Port.
setPort(short) - Method in class org.onlab.packet.lacp.LacpBaseTlv
Sets port.
setPort(PortNumber) - Method in class org.onosproject.net.device.DefaultPortStatistics.Builder
Sets port number.
setPortId(int) - Method in class org.onlab.packet.ONOSLLDP
 
setPortId(LLDPTLV) - Method in class org.onlab.packet.LLDP
 
setPortName(String) - Method in class org.onlab.packet.ONOSLLDP
 
setPortPriority(short) - Method in class org.onlab.packet.lacp.LacpBaseTlv
Sets port priority.
setPps(int) - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
setPps(int) - Method in interface org.onosproject.net.packet.PacketInFilter
Set the pps rate for the current filter type to calculate the max counter allowed with window size.
setPreference(String, String, ObjectNode) - Method in interface org.onosproject.ui.UiPreferencesService
Sets or clears the named preference for the specified user.
setPreferredLifetime(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Sets preferred lifetime.
setPreferredLifetime(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Sets preferred lifetime.
setPrefix(byte[]) - Method in class org.onlab.packet.RIPngEntry
 
setPrefix(Ip4Prefix) - Method in class org.onosproject.net.behaviour.upf.UpfInterface.Builder
Set the IPv4 prefix of this interface.
setPrefixLen(int) - Method in class org.onlab.packet.RIPngEntry
 
setPrefixLength(byte) - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Sets prefix length.
setPriorityCode(byte) - Method in class org.onlab.packet.Ethernet
Sets the priority code.
setProcessedBytes(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
setProcessedBytes(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
setProcessedBytes(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerEntry
Updates the number of bytes seen by the policer.
setProcessedBytes(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucketEntry
Updates the number of bytes seen by this token bucket.
setProcessedBytes(long) - Method in class org.onosproject.net.meter.DefaultMeter
 
setProcessedBytes(long) - Method in interface org.onosproject.net.meter.MeterEntry
Updates the number of bytes seen by the meter.
setProcessedPackets(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
setProcessedPackets(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
setProcessedPackets(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerEntry
Updates the number of packets seen by this policer.
setProcessedPackets(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucketEntry
Updates the number of packets seen by this token bucket.
setProcessedPackets(long) - Method in class org.onosproject.net.meter.DefaultMeter
 
setProcessedPackets(long) - Method in interface org.onosproject.net.meter.MeterEntry
Updates the number of packets seen by this meter.
setProperty(String, String, String) - Method in interface org.onosproject.cfg.ComponentConfigService
Sets the value of the specified configuration property.
setProperty(String, String, String) - Method in interface org.onosproject.cfg.ComponentConfigStore
Sets the value of the specified configuration property.
setProperty(String, String, String) - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
 
setProperty(String, String, String, boolean) - Method in interface org.onosproject.cfg.ComponentConfigStore
Sets the value of the specified configuration property.
setProperty(String, String, String, boolean) - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
 
setProperty(ConfigProperty, String) - Static method in class org.onosproject.cfg.ConfigProperty
Creates a new configuration property as a copy of an existing one, but with a new value.
setPropertyValue(String, T) - Method in class org.onosproject.net.flow.AbstractExtension
 
setPropertyValue(String, T) - Method in interface org.onosproject.net.flow.Extension
Sets a property on the extension.
setProtocol(byte) - Method in class org.onlab.packet.IPv4
 
setProtocolAddressLength(byte) - Method in class org.onlab.packet.ARP
 
setProtocolType(short) - Method in class org.onlab.packet.ARP
 
setQinQPriorityCode(byte) - Method in class org.onlab.packet.Ethernet
Sets the QinQ priority code.
setQinQTPID(short) - Method in class org.onlab.packet.Ethernet
Sets the QinQ TPID.
setQinQVID(short) - Method in class org.onlab.packet.Ethernet
Sets the QinQ VLAN ID.
setQrv(byte) - Method in class org.onlab.packet.IGMPQuery
Set the Querier Robustness Variable.
setQueue(long) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setQueue(long) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the Queue ID.
setQueue(long, PortNumber) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setQueue(long, PortNumber) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a set-queue instruction.
setQueue(long, PortNumber) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the Queue ID for a specific port.
setReachableTime(int) - Method in class org.onlab.packet.ndp.RouterAdvertisement
Sets reachable time.
setRecordType(byte) - Method in class org.onlab.packet.IGMPMembership
Sets the IGMP record type.
setReferenceCount(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
setReferenceCount(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.PolicerEntry
Sets how many are using this policer.
setReferenceCount(long) - Method in class org.onosproject.net.group.DefaultGroup
 
setReferenceCount(long) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets number of flow rules or groups referencing this group entry.
setReferenceCount(long) - Method in class org.onosproject.net.meter.DefaultMeter
 
setReferenceCount(long) - Method in interface org.onosproject.net.meter.MeterEntry
Sets the number of flows which are using this meter.
setRegionId(RegionId) - Method in class org.onosproject.ui.model.topo.UiDevice
Sets the ID of the region to which this device belongs.
setRegionId(RegionId) - Method in class org.onosproject.ui.model.topo.UiHost
Sets the ID of the region to which this device belongs.
setRegistrationRequired(boolean) - Method in class org.onlab.util.KryoNamespace.Builder
Sets the registrationRequired flag.
setReserved(byte) - Method in class org.onlab.packet.PIM
Set the reserved field.
setReserved(short) - Method in class org.onlab.packet.RIP
 
setReserved(short) - Method in class org.onlab.packet.RIPng
 
setResult(PipelineTraceableOutput.PipelineTraceableResult) - Method in class org.onosproject.net.PipelineTraceableOutput.Builder
 
setResv(byte) - Method in class org.onlab.packet.IGMPQuery
Set the reserved field.
setRetransmitTimer(int) - Method in class org.onlab.packet.ndp.RouterAdvertisement
Sets retransmission timer.
setRole(NodeId, DeviceId, MastershipRole) - Method in interface org.onosproject.mastership.MastershipAdminService
Applies the current mastership role for the specified device.
setRoleSync(NodeId, DeviceId, MastershipRole) - Method in interface org.onosproject.mastership.MastershipAdminService
Synchronous version of setRole.
setRootPath(String) - Method in class org.onosproject.common.app.ApplicationArchive
Sets the root directory where apps directory is contained.
setRouterFlag(byte) - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Sets router flag.
setRouterLifetime(short) - Method in class org.onlab.packet.ndp.RouterAdvertisement
Sets router lifetime.
setRouteTag(short) - Method in class org.onlab.packet.RIPngEntry
 
setRouteTag(short) - Method in class org.onlab.packet.RIPV2Entry
 
setRoutingData(byte[]) - Method in class org.onlab.packet.ipv6.Routing
Sets the routing data.
setRoutingType(byte) - Method in class org.onlab.packet.ipv6.Routing
Sets the routing type of this header.
setRtEntries(List<RIPngEntry>) - Method in class org.onlab.packet.RIPng
 
setRtEntries(List<RIPV2Entry>) - Method in class org.onlab.packet.RIP
 
setSAK(byte[]) - Method in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
setSamenessThreshold(double) - Static method in class org.onlab.graph.ScalarWeight
Sets a new sameness threshold for comparing cost values; default is is Double.MIN_VALUE.
setSbit(boolean) - Method in class org.onlab.packet.IGMPQuery
Set the S flag.
setSci(byte[]) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set SCI.
setSci(EAPOLMkpduBasicParameterSet.SCI) - Method in class org.onlab.packet.EAPOLMkpduBasicParameterSet
To set SCI.
setSeconds(short) - Method in class org.onlab.packet.DHCP
 
setSecurityParamIndex(int) - Method in class org.onlab.packet.ipv6.Authentication
Sets the security parameter index of this header.
setSecurityParamIndex(int) - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
Sets the security parameter index of this header.
setSegmntsLeft(byte) - Method in class org.onlab.packet.ipv6.Routing
Sets the number of remaining route segments of this header.
setSenderHardwareAddress(byte[]) - Method in class org.onlab.packet.ARP
 
setSenderProtocolAddress(byte[]) - Method in class org.onlab.packet.ARP
 
setSenderProtocolAddress(int) - Method in class org.onlab.packet.ARP
 
setSequence(int) - Method in class org.onlab.packet.ipv6.Authentication
Sets the sequence number of this header.
setSequence(int) - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
Sets the sequence number of this header.
setSequence(int) - Method in class org.onlab.packet.TCP
Sets sequence number.
setSequenceNum(short) - Method in class org.onlab.packet.ICMPEcho
Sets the sequencer number.
setSequenceNumber(int) - Method in class org.onlab.packet.RIPV2AuthEntry
 
setServerIPAddress(int) - Method in class org.onlab.packet.DHCP
 
setServerName(String) - Method in class org.onlab.packet.DHCP
 
setSessionId(short) - Method in class org.onlab.packet.PPPoED
 
setSig(byte[]) - Method in class org.onlab.packet.ONOSLLDP
 
setSinkIp(IpAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets the sink IP address to the config.
setSinkMac(MacAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets the sink mac address to the config.
setSinkPort(PortNumber) - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
Configures the given port as an INT sink port.
setSolicitedFlag(byte) - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Sets solicited flag.
setSourceAddress(byte[]) - Method in class org.onlab.packet.IPv6
Sets source address.
setSourceAddress(int) - Method in class org.onlab.packet.IPv4
 
setSourceAddress(String) - Method in class org.onlab.packet.IPv4
 
setSourceMACAddress(byte[]) - Method in class org.onlab.packet.Ethernet
Sets the source MAC address.
setSourceMACAddress(String) - Method in class org.onlab.packet.Ethernet
Sets the source MAC address.
setSourceMACAddress(MacAddress) - Method in class org.onlab.packet.Ethernet
Sets the source MAC address.
setSourcePort(int) - Method in class org.onlab.packet.TCP
Sets TCP source port.
setSourcePort(int) - Method in class org.onlab.packet.UDP
 
setSourcePort(PortNumber) - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
Configures the given port as an INT source port.
setSrc(Ip4Address) - Method in class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
Set the source IP address of the unidirectional GTP tunnel.
setSrcPort(short) - Method in class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
Set the source port of this unidirectional GTP tunnel.
setSsap(byte) - Method in class org.onlab.packet.LLC
 
setStandby(NodeId, DeviceId) - Method in interface org.onosproject.mastership.MastershipStore
Sets a controller instance's mastership role to STANDBY for a device.
setState(byte) - Method in class org.onlab.packet.lacp.LacpBaseTlv
Sets state.
setState(FlowEntry.FlowEntryState) - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
setState(FlowEntry.FlowEntryState) - Method in interface org.onosproject.net.flow.StoredFlowEntry
Sets the new state for this entry.
setState(Group.GroupState) - Method in class org.onosproject.net.group.DefaultGroup
Sets the new state for this entry.
setState(Group.GroupState) - Method in interface org.onosproject.net.group.StoredGroupEntry
Sets the new state for this entry.
setState(IntentState) - Method in class org.onosproject.net.intent.IntentData
Updates the state of the intent to the given new state.
setState(MeterState) - Method in class org.onosproject.net.meter.DefaultMeter
 
setState(MeterState) - Method in interface org.onosproject.net.meter.MeterEntry
Updates the state of this meter.
setStaticMapping(MacAddress, IpAssignment) - Method in interface org.onosproject.dhcp.DhcpService
Registers a static IP mapping with the DHCP Server.
setSubnetMask(Ip4Address) - Method in class org.onlab.packet.RIPV2Entry
 
setSubtype(byte) - Method in class org.onlab.packet.Slow
Sets subtype.
setSubType(byte) - Method in class org.onlab.packet.LLDPOrganizationalTLV
Set the value of sub type.
setSync(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets sync bit.
setSystemMac(MacAddress) - Method in class org.onlab.packet.lacp.LacpBaseTlv
Sets system MAC address.
setSystemPriority(short) - Method in class org.onlab.packet.lacp.LacpBaseTlv
Sets system priority.
setT1(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Sets time 1.
setT1(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Sets time 1.
setT2(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
Sets time 2.
setT2(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
Sets time 2.
setTag(short, byte[]) - Method in class org.onlab.packet.PPPoED
Sets a tag in the packet.
setTags(List<PPPoEDTag>) - Method in class org.onlab.packet.PPPoED
 
setTargetAddress(byte[]) - Method in class org.onlab.packet.ndp.NeighborAdvertisement
Sets target address.
setTargetAddress(byte[]) - Method in class org.onlab.packet.ndp.NeighborSolicitation
Sets target address.
setTargetAddress(byte[]) - Method in class org.onlab.packet.ndp.Redirect
Sets target address.
setTargetHardwareAddress(byte[]) - Method in class org.onlab.packet.ARP
 
setTargetPower(PortNumber, T, double) - Method in interface org.onosproject.net.behaviour.PowerConfig
Set the target power on the component.
setTargetProtocolAddress(byte[]) - Method in class org.onlab.packet.ARP
 
setTargetProtocolAddress(int) - Method in class org.onlab.packet.ARP
 
setTcpDst(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setTcpDst(TpPort) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the dst TCP port.
setTcpSrc(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setTcpSrc(TpPort) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the src TCP port.
setTeid(long) - Method in class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
Set the identifier of this unidirectional GTP tunnel.
setTeid(ImmutableByteSequence) - Method in class org.onosproject.net.behaviour.upf.GtpTunnel.GtpTunnelBuilder
Set the identifier of this unidirectional GTP tunnel.
setTimeout(boolean) - Method in class org.onlab.packet.lacp.LacpState
Sets timeout bit.
setTimestamp(long) - Method in class org.onlab.packet.ONOSLLDP
 
setTlv(Map<Byte, LacpTlv>) - Method in class org.onlab.packet.lacp.Lacp
Sets LACP TLV.
setTotal(long) - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
Set total memory of device.
setTrafficClass(byte) - Method in class org.onlab.packet.IPv6
Sets traffic class.
setTrafficPeriod(long) - Static method in class org.onosproject.ui.topo.AbstractTopoMonitor
Sets the traffic refresh period in milliseconds.
setTransactionId(int) - Method in class org.onlab.packet.DHCP
 
setTransactionId(int) - Method in class org.onlab.packet.DHCP6
Sets transaction id.
setTruncated(boolean) - Method in class org.onlab.packet.IPv4
 
setTtl(byte) - Method in class org.onlab.packet.IPv4
 
setTtl(byte) - Method in class org.onlab.packet.MPLS
Sets the MPLS TTL of the packet.
setTtl(LLDPTLV) - Method in class org.onlab.packet.LLDP
 
setTunnel(Ip4Address, Ip4Address, ImmutableByteSequence) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set the unidirectional GTP tunnel that this FAR should encapsulate packets with.
setTunnel(Ip4Address, Ip4Address, ImmutableByteSequence, short) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set the unidirectional GTP tunnel that this FAR should encapsulate packets with.
setTunnel(GtpTunnel) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set the GTP tunnel that this FAR should encapsulate packets with.
setTunnelId(long) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setTunnelId(long) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the tunnel id.
setType(byte) - Method in class org.onlab.packet.bmp.Bmp
Sets message type.
setType(byte) - Method in class org.onlab.packet.ipv6.BaseOptions
Sets the type of this option.
setType(byte) - Method in class org.onlab.packet.LLDPTLV
 
setType(byte) - Method in class org.onlab.packet.PPPoED
 
setType(byte) - Method in class org.onlab.packet.RADIUSAttribute
Sets the attribute type.
setType(short) - Method in class org.onlab.packet.PPPoEDTag
 
setType(short) - Method in class org.onlab.packet.RIPV2AuthEntry
 
setType(PathIntent.ProtectionType) - Method in class org.onosproject.net.intent.PathIntent.Builder
 
setUdpDst(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setUdpDst(TpPort) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the dst UDP port.
setUdpSrc(TpPort) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setUdpSrc(TpPort) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the src UDP port.
setupAttachment(BngProgrammable.Attachment) - Method in interface org.onosproject.net.behaviour.BngProgrammable
Set up the necessary state to enable termination of the attachment traffic.
setupIntConfig(IntDeviceConfig) - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
Set up report-related configuration.
setupRuntimeLocale() - Static method in class org.onosproject.ui.lion.LionUtils
Sets the default locale, based on the Java properties shown below.
setUpstreamAddr(PIMAddrUnicast) - Method in class org.onlab.packet.pim.PIMJoinPrune
Set the upstream address of this PIM J/P request.
setUrgentPointer(short) - Method in class org.onlab.packet.TCP
Sets urgent pointer.
setUsed(float) - Method in class org.onosproject.net.behaviour.DeviceCpuStats
Set cpu usage of device.
setUsed(long) - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
Set used memory of device.
setUuid(byte[]) - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
setValidLifetime(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
Sets valid lifetime.
setValidLifetime(int) - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
Sets valid lifetime.
setValue(byte[]) - Method in class org.onlab.packet.LLDPTLV
 
setValue(byte[]) - Method in class org.onlab.packet.pim.PIMHelloOption
 
setValue(byte[]) - Method in class org.onlab.packet.PPPoEDTag
 
setValue(byte[]) - Method in class org.onlab.packet.RADIUSAttribute
Sets the attribute value.
setValue(ByteBuffer) - Method in class org.onlab.packet.pim.PIMHelloOption
 
setVersion(byte) - Method in class org.onlab.packet.bmp.Bmp
Sets version field.
setVersion(byte) - Method in class org.onlab.packet.EAPOL
Sets the version.
setVersion(byte) - Method in class org.onlab.packet.IP
Sets IP version number.
setVersion(byte) - Method in class org.onlab.packet.IPv4
 
setVersion(byte) - Method in class org.onlab.packet.IPv6
 
setVersion(byte) - Method in class org.onlab.packet.PIM
Set the PIM version type.
setVersion(byte) - Method in class org.onlab.packet.PPPoED
 
setVersion(byte) - Method in class org.onlab.packet.RIP
 
setVersion(byte) - Method in class org.onlab.packet.RIPng
 
setVlanId(short) - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
Sets the vlan id of interface id.
setVlanId(VlanId) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setVlanId(VlanId) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the vlan id.
setVlanID(short) - Method in class org.onlab.packet.Ethernet
Sets the VLAN ID.
setVlanPcp(Byte) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
setVlanPcp(Byte) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the vlan priority.
setVni(int) - Method in class org.onlab.packet.VXLAN
Set VNI.
setWatchSubnets(Set<IpPrefix>) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Sets subnets to be watched.
setWindowSize(short) - Method in class org.onlab.packet.TCP
Sets TCP window size.
setWinSize(int) - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
setWinSize(int) - Method in interface org.onosproject.net.packet.PacketInFilter
Set the window size for rate limiting.
setWinThres(int) - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
setWinThres(int) - Method in interface org.onosproject.net.packet.PacketInFilter
Set the Window Threshold for dropping the packet.
setYourIPAddress(int) - Method in class org.onlab.packet.DHCP
 
severity() - Method in interface org.onosproject.alarm.Alarm
Returns the severity.
severity() - Method in class org.onosproject.alarm.DefaultAlarm
 
SFQ - org.onosproject.net.behaviour.QosDescription.Type
Corresponds to Stochastic Fairness Queueing classifier.
SHARED_THREAD_POOL_SIZE - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
SHARED_THREAD_POOL_SIZE_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
SharedExecutors - Class in org.onlab.util
Utility for managing a set of shared execution resources, such as a timer, single thread executor and thread pool executor for use by various parts of the platform or by applications.
SharedScheduledExecutors - Class in org.onlab.util
Utility for managing a set of shared execution resources, such as a single thread scheduled executor and thread pool scheduled executor for use by various parts of the platform or by applications.
SharedScheduledExecutorService - Class in org.onlab.util
A new scheduled executor service that does not eat exception.
SHORT - org.onosproject.net.flow.FlowEntry.FlowLiveType
Indicates that this rule has been submitted for a short time.
SHORT_FLOW - org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Indicates that this rule has been submitted for a short time.
shortLoad() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Returns short load of connect point.
SHOW_DEVICE_VIEW - Static variable in class org.onosproject.ui.topo.TopoConstants.CoreButtons
 
SHOW_FLOW_VIEW - Static variable in class org.onosproject.ui.topo.TopoConstants.CoreButtons
 
SHOW_GROUP_VIEW - Static variable in class org.onosproject.ui.topo.TopoConstants.CoreButtons
 
SHOW_METER_VIEW - Static variable in class org.onosproject.ui.topo.TopoConstants.CoreButtons
 
SHOW_PORT_VIEW - Static variable in class org.onosproject.ui.topo.TopoConstants.CoreButtons
 
shutdown() - Method in class org.onlab.junit.NullScheduledExecutor
 
shutdown() - Method in class org.onlab.util.PredictableExecutor
 
shutdown() - Static method in class org.onlab.util.SharedExecutors
Shuts down all shared timers and executors and therefore should be called only by the framework.
shutdown() - Static method in class org.onlab.util.SharedScheduledExecutors
Shuts down all shared scheduled executors.
shutdown() - Method in class org.onlab.util.SharedScheduledExecutorService
 
shutdown() - Method in class org.onosproject.routing.AsyncDeviceFetcher
Shuts down.
shutdownNow() - Method in class org.onlab.junit.NullScheduledExecutor
 
shutdownNow() - Method in class org.onlab.util.PredictableExecutor
 
shutdownNow() - Method in class org.onlab.util.SharedScheduledExecutorService
 
SIG_SUBTYPE - Static variable in class org.onlab.packet.ONOSLLDP
 
signalType() - Method in class org.onosproject.net.flow.criteria.OchSignalTypeCriterion
Returns the OCh signal type to match.
signalType() - Method in class org.onosproject.net.flow.criteria.OduSignalTypeCriterion
Returns the ODU Signal Type to match.
signalType() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
signalType(CltSignalType) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
Sets the ODU signal type for the intent that will be built.
signalType(CltSignalType) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
Sets the ODU signal type for the intent that will be built.
signalType(OchSignalType) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
Sets the optical signal type for the intent that will be built.
signalType(OduSignalType) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
Sets the ODU signal type for the intent that will be built.
SIMPLE - org.onosproject.net.flowobjective.NextObjective.Type
Simple processing.
simpleTypeName() - Method in class org.onosproject.net.resource.ContinuousResource
 
simpleTypeName() - Method in class org.onosproject.net.resource.DiscreteResource
 
simpleTypeName() - Method in interface org.onosproject.net.resource.Resource
Returns the simple type name of this resource.
simplify(String) - Static method in class org.onosproject.cli.net.IntentDetailsCommand
Simplify toString result for CLI.
SinglePointToMultiPointIntent - Class in org.onosproject.net.intent
Abstraction of single source, multiple destination connectivity intent.
SinglePointToMultiPointIntent() - Constructor for class org.onosproject.net.intent.SinglePointToMultiPointIntent
Constructor for serializer.
SinglePointToMultiPointIntent.Builder - Class in org.onosproject.net.intent
Builder of a single point to multi point intent.
sink() - Method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
The sink which has been removed or added.
SINK - org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable.IntFunctionality
Sink functionality.
SINK_ADDED - org.onosproject.net.mcast.McastEvent.Type
Deprecated.
A sink for a mcast route (ie.
SINK_REMOVED - org.onosproject.net.mcast.McastEvent.Type
Deprecated.
A source for a mcast route (ie.
sinkIp() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
Returns IP address of the sink device.
sinkIp() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Returns IP address of the sink device.
sinkMac() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
Returns MAC address of the sink device.
sinkMac() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Returns MAC address of the sink device.
sinks() - Method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
Returns the set of sinks associated with this route.
sinksFor(McastRoute) - Method in interface org.onosproject.net.mcast.McastStore
Deprecated.
Obtains the sinks for a multicast route.
size() - Method in class org.onlab.graph.DisjointPathPair
Returns number of paths inside this path pair object.
size() - Method in class org.onlab.graph.Heap
Returns the current size of the heap.
size() - Method in class org.onlab.util.ExtendedSet
 
size() - Method in class org.onlab.util.ImmutableByteSequence
Gets the number of bytes in this sequence.
size() - Method in class org.onlab.util.KryoNamespace
Gets the number of classes registered in this Kryo namespace.
size() - Method in class org.onlab.util.UnmodifiableDeque
 
size() - Method in class org.onosproject.net.flow.BatchOperation
Returns the number of operations in this object.
size() - Method in interface org.onosproject.net.pi.model.PiActionProfileModel
Returns the maximum number of member entries that this action profile can hold.
size() - Method in interface org.onosproject.net.pi.model.PiCounterModel
Returns the number of cells of this counter.
size() - Method in interface org.onosproject.net.pi.model.PiMeterModel
Returns the number of cells of this meter.
size() - Method in interface org.onosproject.net.pi.model.PiRegisterModel
Returns the number of cells of this register.
size() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
size() - Method in class org.onosproject.store.primitives.DefaultAtomicCounterMap
 
size() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
size() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
size() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
size() - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
size() - Method in interface org.onosproject.store.service.AsyncAtomicCounterMap
Returns the number of entries in the map.
size() - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns the number of entries in the map.
size() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns the number of key-value pairs in this multimap.
size() - Method in interface org.onosproject.store.service.AsyncDistributedSet
Returns the number of elements in the set.
size() - Method in interface org.onosproject.store.service.AtomicCounterMap
Returns the number of entries in the map.
size() - Method in interface org.onosproject.store.service.ConsistentMap
Returns the number of entries in the map.
size() - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns the number of key-value pairs in this multimap.
size() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Returns the number of key-value mappings in this map.
size() - Method in class org.onosproject.store.service.MapInfo
Returns the number of entries in the map.
size() - Method in class org.onosproject.ui.chart.ChartModel.DataPoint
Returns the size of data point.
size() - Method in class org.onosproject.ui.lion.LionBundle
Returns the number of entries in this bundle.
size() - Method in class org.onosproject.ui.topo.BiLinkMap
Returns the number of bi-links in the collection.
SLASH - Static variable in class org.onosproject.ui.table.cell.AbstractCellFormatter
 
SlidingWindowCounter - Class in org.onlab.util
Maintains a sliding window of value counts.
SlidingWindowCounter(int) - Constructor for class org.onlab.util.SlidingWindowCounter
Creates a new sliding window counter with the given total number of window slots.
slotGranularity() - Method in class org.onosproject.net.OchSignal
Returns slot width granularity.
slotWidth() - Method in class org.onosproject.net.OchSignal
Returns slot width.
Slow - Class in org.onlab.packet
Implements ethernet slow protocols.
Slow() - Constructor for class org.onlab.packet.Slow
 
SLOW - org.onlab.packet.EthType.EtherType
 
SLOWPATH - Static variable in class org.onosproject.net.meter.MeterId
Meter for slow datapath, if any.
snapshot() - Method in interface org.onosproject.store.primitives.PartitionAdminService
Takes a snapshot of all partitions.
snapshot(PartitionId) - Method in interface org.onosproject.store.primitives.PartitionAdminService
Takes a snapshot of the given partition.
SoftwareUpgrade - Interface in org.onosproject.net.behaviour
Behaviour that upgrades the software on a device.
SoftwareUpgrade.Status - Enum in org.onosproject.net.behaviour
Completion status of upgrade.
SOLICIT - org.onlab.packet.DHCP6.MsgType
 
solicitedFlag - Variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
sort(String, TableModel.SortDir, String, TableModel.SortDir) - Method in class org.onosproject.ui.table.TableModel
Sorts the table rows based on the specified columns, in the specified directions.
sortDir(String) - Static method in class org.onosproject.ui.table.TableModel
Returns the appropriate sort direction for the given string.
source() - Method in interface org.onosproject.alarm.Alarm
Returns an entity within the context of this alarm's device.
source() - Method in class org.onosproject.alarm.DefaultAlarm
 
source() - Method in class org.onosproject.net.mcast.McastRoute
Deprecated.
Fetches the source address of this route.
source() - Method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
The source which has been removed or added.
source() - Method in class org.onosproject.upgrade.Upgrade
Returns the source version.
SOURCE - org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable.IntFunctionality
Source functionality.
SOURCE_ADDED - org.onosproject.net.mcast.McastEvent.Type
Deprecated.
A source for a mcast route (ie.
SOURCE_UPDATED - org.onosproject.net.mcast.McastEvent.Type
Deprecated.
A source for a mcast route has been updated.
sourceAddress - Variable in class org.onlab.packet.IPv4
 
sourceAddress - Variable in class org.onlab.packet.IPv6
 
sourceFor(McastRoute) - Method in interface org.onosproject.net.mcast.McastStore
Deprecated.
Obtains the source for a multicast route.
sourceMACAddress - Variable in class org.onlab.packet.Ethernet
 
sourcePort - Variable in class org.onlab.packet.TCP
 
sourcePort - Variable in class org.onlab.packet.UDP
 
sources - Variable in class org.onlab.packet.IGMPGroup
 
SPACE - Static variable in class org.onosproject.ui.table.cell.AbstractCellFormatter
 
spacingMultiplier() - Method in class org.onosproject.net.OchSignal
Returns spacing multiplier.
SpanningTreeResult(V, V, int) - Constructor for class org.onlab.graph.DepthFirstSearch.SpanningTreeResult
Creates a new spanning tree result.
SparseAnnotations - Interface in org.onosproject.net
Represents an set of sparse key/value string annotations capable of carrying annotation keys tagged for removal.
SPEAKERS - Static variable in class org.onosproject.routing.config.BgpConfig
 
spec() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig
Returns the type of telemetry spec as per IntDeviceConfig.TelemetrySpec.
SPECIFIC - org.onosproject.net.flowobjective.ForwardingObjective.Flag
A decomposable objective.
Spectrum - Class in org.onlab.util
Telecom optical wavelength bands: O, E, S, C, L and U bands.
SPECTRUM_BIN - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Mellanox Spectrum configuration binary.
split(String, int, String) - Method in class org.onosproject.rest.AbstractInjectionResource
Returns the index into the supplied string where the end of the specified pattern is located.
spliterator() - Method in class org.onlab.util.UnmodifiableDeque
 
sprites() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Returns the identifier for the background sprites.
sprites() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Returns the symbolic name for the sprites definition for this layout.
sprites(String) - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
Sets the name of the sprites definition to use for this layout.
sprites(String) - Method in class org.onosproject.ui.model.topo.UiTopoLayout
Sets the name of the sprites definition for this layout.
src() - Method in class org.onlab.graph.AbstractEdge
 
src() - Method in class org.onlab.graph.AbstractGraphPathSearch.DefaultResult
 
src() - Method in class org.onlab.graph.DefaultMutablePath
 
src() - Method in class org.onlab.graph.DefaultPath
 
src() - Method in class org.onlab.graph.DisjointPathPair
 
src() - Method in interface org.onlab.graph.Edge
Returns the edge source vertex.
src() - Method in interface org.onlab.graph.GraphPathSearch.Result
Returns the search source.
src() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
Get the source IP address of this unidirectional GTP tunnel.
src() - Method in class org.onosproject.net.DefaultLink
 
src() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
src() - Method in class org.onosproject.net.link.DefaultLinkDescription
 
src() - Method in interface org.onosproject.net.link.LinkDescription
Returns the link source.
src() - Method in interface org.onosproject.net.Link
Returns the link source connection point.
src() - Method in class org.onosproject.net.LinkKey
Returns source connection point.
src() - Method in class org.onosproject.net.topology.DefaultTopologyEdge
 
src(ConnectPoint) - Method in class org.onosproject.net.DefaultLink.Builder
Sets the source connect point to be used by the builder.
src(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
Sets the source for the intent that will be built.
src(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
Sets the source for the intent that will be built.
src(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalOduIntent.Builder
Sets the source for the intent that will be built.
src(ConnectPoint) - Method in class org.onosproject.net.intent.OpticalPathIntent.Builder
Sets the source for the intent that will be built.
SRC_ROUTING_HEADER_ERR - org.onosproject.cli.net.Icmp6Code
Error in Source Routing Header.
SRC_ROUTING_HEADER_ERR - Static variable in class org.onlab.packet.ICMP6
Error in Source Routing Header.
srcMac() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the source MAC address of the message.
srcPort() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
Get the source L4 port of this unidirectional GTP tunnel.
SrlgGraphSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
SRLG Graph Search finds a pair of paths with disjoint risk groups; i.e if one path goes through an edge in risk group 1, the other path will go through no edges in risk group 1.
SrlgGraphSearch(int, Map<E, Integer>) - Constructor for class org.onlab.graph.SrlgGraphSearch
Creates an SRLG graph search object with the given number of groups and given risk mapping.
SrlgGraphSearch(Map<E, Object>) - Constructor for class org.onlab.graph.SrlgGraphSearch
Creates an SRLG graph search object from a map, inferring the number of groups and creating an integral mapping.
SSHKEY - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the sshkey.
SSL_KEY - org.onosproject.net.key.DeviceKey.Type
 
sTag() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
Returns the VLAN S-tag of the attachment.
stages() - Method in class org.onosproject.net.domain.DomainIntentOperations
Returns the domain intent operations as sets of stages that should be executed sequentially.
stages() - Method in class org.onosproject.net.flow.FlowRuleOperations
Returns the flow rule operations as sets of stages that should be executed sequentially.
STANDALONE - org.onosproject.net.behaviour.BridgeDescription.FailMode
The bridge will take over responsibility of setting up flows.
STANDBY - org.onosproject.net.MastershipRole
Represents a relationship where the controller instance is the standby, i.e.
start() - Method in interface org.onosproject.store.service.MutexTask
Begins the execution of a mutually exclusive task.
START - Static variable in class org.onosproject.cli.StartStopCompleter
 
startIndex() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
startIndex() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns the start index (inclusive) of the meters.
startMonitoringIp(IpAddress) - Method in interface org.onosproject.net.host.HostService
Requests the host service to monitor hosts with the given IP address and notify listeners of changes.
startReport() - Method in interface org.onlab.metrics.MetricsReporter
Starts to report a set of metrics to the monitoring server.
StartStopCompleter - Class in org.onosproject.cli
Start/stop command completer.
StartStopCompleter() - Constructor for class org.onosproject.cli.StartStopCompleter
 
startTimer(Timer) - Static method in class org.onlab.metrics.MetricsUtil
Starts the Metric Timer.
startTimer(String) - Method in class org.onosproject.utils.MeteringAgent
Initializes a specific timer for a given operation.
STAT_TRIGGER - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that statistics will be triggered.
state() - Method in class org.onosproject.net.DefaultLink
 
state() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
state() - Method in interface org.onosproject.net.flow.FlowEntry
Returns the flow entry state.
state() - Method in class org.onosproject.net.group.DefaultGroup
Returns current state of a group object.
state() - Method in interface org.onosproject.net.group.Group
Returns current state of a group object.
state() - Method in class org.onosproject.net.intent.IntentData
Returns the state of the intent.
state() - Method in interface org.onosproject.net.Link
Returns the link state.
state() - Method in class org.onosproject.net.meter.DefaultMeter
 
state() - Method in interface org.onosproject.net.meter.Meter
Fetches the state of this meter.
state(Link.State) - Method in class org.onosproject.net.DefaultLink.Builder
Sets the link state to be used by the builder.
STATIC - org.onosproject.net.mcast.McastRoute.Type
Deprecated.
Route originates from other config (ie.
STATIC_LAMBDA - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the static lambda.
STATIC_PORT - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the static port.
STATISTIC_READ - org.onosproject.security.AppPermission.Type
 
StatisticService - Interface in org.onosproject.net.statistic
Service for obtaining statistic information about link in the system.
StatisticStore - Interface in org.onosproject.net.statistic
Store to house the computed statistics.
stats() - Method in interface org.onosproject.store.service.WorkQueue
Returns work queue statistics.
STATS_UPDATE - org.onosproject.cpman.message.ControlMessageEvent.Type
signifies that the control message stats has been updated.
statTrigger() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
statTrigger() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the stat trigger instruction if there is one.
statTrigger(Map<StatTriggerField, Long>, StatTriggerFlag) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
statTrigger(Map<StatTriggerField, Long>, StatTriggerFlag) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a stat trigger instruction.
statTrigger(Map<StatTriggerField, Long>, StatTriggerFlag) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Add stat trigger instruction.
StatTriggerField - Enum in org.onosproject.net.flow
Stat fields are supported default by OXS.
StatTriggerFlag - Enum in org.onosproject.net.flow
Stat Trigger Flags.
status() - Method in class org.onosproject.ui.topo.NodeBadge
Returns the badge status.
status() - Method in class org.onosproject.upgrade.Upgrade
Returns the upgrade status.
STATUS_CODE - org.onlab.packet.DHCP6.OptionCode
 
statusChangeListeners() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
statusChangeListeners() - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
statusChangeListeners() - Method in interface org.onosproject.store.service.DistributedPrimitive
Returns the collection of status change listeners previously registered.
stop() - Method in class org.onosproject.net.packet.packetfilter.DefaultPacketInFilter
 
stop() - Method in interface org.onosproject.net.packet.PacketInFilter
Stop the threads running for this filter.
stop() - Method in interface org.onosproject.store.service.MutexTask
This method will be called when exclusivity of task execution can no longer be guaranteed.
stop(Throwable) - Method in class org.onosproject.utils.MeteringAgent.Context
Stops timer given a specific context and updates all related metrics.
STOP - Static variable in class org.onosproject.cli.StartStopCompleter
 
STOP - Static variable in class org.onosproject.ui.GlyphConstants
 
stopMonitoringIp(IpAddress) - Method in interface org.onosproject.net.host.HostService
Stops the host service from monitoring an IP address.
stopProcessing() - Method in interface org.onosproject.store.service.WorkQueue
Stops automatically processing tasks from work queue.
stopReport() - Method in interface org.onlab.metrics.MetricsReporter
Stops reporting metrics.
stopTimer(Timer.Context) - Static method in class org.onlab.metrics.MetricsUtil
Stops the Metric Timer context.
STORAGE - org.onosproject.cluster.ClusterEvent.InstanceType
Signifies that the event refers to an Atomix instance.
STORAGE_WRITE - org.onosproject.security.AppPermission.Type
 
StorageAdminService - Interface in org.onosproject.store.service
Service for administering storage instances.
StorageException - Exception in org.onosproject.store.service
Top level exception for Store failures.
StorageException() - Constructor for exception org.onosproject.store.service.StorageException
 
StorageException(String) - Constructor for exception org.onosproject.store.service.StorageException
 
StorageException(Throwable) - Constructor for exception org.onosproject.store.service.StorageException
 
StorageException.ConcurrentModification - Exception in org.onosproject.store.service
Store update conflicts with an in flight transaction.
StorageException.Interrupted - Exception in org.onosproject.store.service
Store operation interrupted.
StorageException.Timeout - Exception in org.onosproject.store.service
Store operation timeout.
StorageException.Unavailable - Exception in org.onosproject.store.service
Store is temporarily unavailable.
StorageNodesListCommand - Class in org.onosproject.cli
Lists all storage nodes.
StorageNodesListCommand() - Constructor for class org.onosproject.cli.StorageNodesListCommand
 
storageService - Variable in class org.onosproject.store.app.DistributedApplicationStore
 
storageService - Variable in class org.onosproject.store.cfg.DistributedComponentConfigStore
 
StorageService - Interface in org.onosproject.store.service
Storage service.
store() - Method in interface org.onosproject.net.behaviour.PipelinerContext
Returns the Objective Store where data can be stored and retrieved.
Store<E extends Event,​D extends StoreDelegate<E>> - Interface in org.onosproject.store
Abstraction of a entity capable of storing and/or distributing information across a cluster.
STORE_COMMON - Static variable in class org.onosproject.store.serializers.custom.DistributedStoreSerializers
KryoNamespace which can serialize ONF misc classes.
STORE_CUSTOM_BEGIN - Static variable in class org.onosproject.store.serializers.custom.DistributedStoreSerializers
 
storeBatch(FlowRuleBatchOperation) - Method in interface org.onosproject.net.flow.FlowRuleStore
Stores a batch of flow rules.
StoreDelegate<E extends Event> - Interface in org.onosproject.store
Entity associated with a store and capable of receiving notifications of events within the store.
storedFlowEntry() - Method in class org.onosproject.net.statistic.FlowEntryWithLoad
Returns stored flow entry.
StoredFlowEntry - Interface in org.onosproject.net.flow
 
StoredGroupBucketEntry - Interface in org.onosproject.net.group
Generic group bucket entry representation that is stored in a group object.
StoredGroupEntry - Interface in org.onosproject.net.group
Interface that defines set methods for a group entry that is stored in the system.
storeFlowRule(FlowRule) - Method in interface org.onosproject.net.flow.FlowRuleStore
Deprecated.
in Cardinal Release
storeGroupDescription(GroupDescription) - Method in interface org.onosproject.net.group.GroupStore
Stores a new group entry using the information from group description.
storeMeterFeatures(Collection<MeterFeatures>) - Method in interface org.onosproject.net.meter.MeterStore
Adds a collection of meter features to the store.
storeMeterFeatures(MeterFeatures) - Method in interface org.onosproject.net.meter.MeterStore
Adds the meter features to the store.
storeRoute(McastRoute, McastStore.Type) - Method in interface org.onosproject.net.mcast.McastStore
Deprecated.
Updates the store with the route information.
StoreSerializer - Interface in org.onosproject.store.serializers
Deprecated.
since 1.11 ("Loon")
storeSink(McastRoute, ConnectPoint, McastStore.Type) - Method in interface org.onosproject.net.mcast.McastStore
Deprecated.
Updates the store with sink information for a given route.
storeSource(McastRoute, ConnectPoint) - Method in interface org.onosproject.net.mcast.McastStore
Deprecated.
Updates the store with source information for the given route.
STRATUM_FPM_BIN - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Stratum Fixed Pipeline Model (FPM) pipeline configuration binary.
stream() - Method in class org.onlab.util.UnmodifiableDeque
 
stream() - Method in interface org.onosproject.store.service.ConsistentMap
Streams entries from the map.
stream() - Method in interface org.onosproject.store.service.ConsistentMultimap
Streams entries from the map.
stream(Iterable<T>) - Static method in class org.onlab.util.Tools
Converts an iterable to a stream.
stream(String, int, int) - Method in class org.onosproject.rest.AbstractInjectionResource
Produces an input stream from the bytes of the specified sub-string.
stream(Optional<? extends T>) - Static method in class org.onlab.util.Tools
Converts an optional to a stream.
StreamEnumeration(List<InputStream>) - Constructor for class org.onosproject.rest.AbstractInjectionResource.StreamEnumeration
 
string(ObjectNode, String) - Static method in class org.onosproject.ui.JsonUtils
Returns the specified node property as a string.
string(ObjectNode, String) - Method in class org.onosproject.ui.RequestHandler
Returns the specified node property as a string.
string(ObjectNode, String, String) - Static method in class org.onosproject.ui.JsonUtils
Returns the specified node property as a string, with a default fallback.
string(ObjectNode, String, String) - Method in class org.onosproject.ui.RequestHandler
Returns the specified node property as a string, with a default fallback.
STRING - org.onosproject.cfg.ConfigProperty.Type
Indicates the value is a string.
StringFilter - Class in org.onlab.util
Filters content on a given object with String representation.
StringFilter(List<String>) - Constructor for class org.onlab.util.StringFilter
Creates a new filter to apply on some data.
StringFilter(List<String>, StringFilter.Strategy) - Constructor for class org.onlab.util.StringFilter
Creates a new filter to apply on some data, given a specific strategy (AND, OR).
StringFilter.Strategy - Enum in org.onlab.util
Defines the filtering strategy.
struct() - Method in class org.onosproject.net.pi.runtime.data.PiStruct
Return protocol-independent struct instance.
STRUCT - org.onosproject.net.pi.model.PiData.Type
Struct.
strValue() - Method in class org.onosproject.net.behaviour.TunnelEndPoint
Returns the value as a string.
strValue() - Method in class org.onosproject.net.behaviour.TunnelKey
Returns the value as a string.
subdueAllElse(Highlights.Amount) - Method in class org.onosproject.ui.topo.Highlights
Marks the amount by which all other elements (devices, hosts, links) not explicitly referenced here will be "subdued" visually.
subdued() - Method in class org.onosproject.ui.topo.AbstractHighlight
Returns the subdued flag.
subdueLevel() - Method in class org.onosproject.ui.topo.Highlights
Returns the amount by which all other elements not explicitly referenced here should be "subdued".
subject - Variable in class org.onosproject.net.config.Config
 
subject() - Method in class org.onosproject.event.AbstractEvent
 
subject() - Method in interface org.onosproject.event.Event
Returns the subject of the event.
subject() - Method in class org.onosproject.net.config.Config
Returns the specific subject to which this configuration pertains.
subject() - Method in exception org.onosproject.net.config.InvalidConfigException
Returns the string representation of the subject of the config.
subject() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
Returns the message subject indicator.
subjectClass() - Method in class org.onosproject.net.config.SubjectFactory
Returns the class of the subject to which this factory applies.
subjectClassKey() - Method in class org.onosproject.net.config.SubjectFactory
Returns the unique key of this configuration subject class.
SubjectClassKeyCompleter - Class in org.onosproject.cli.cfg
Network configuration subject class key completer.
SubjectClassKeyCompleter() - Constructor for class org.onosproject.cli.cfg.SubjectClassKeyCompleter
 
SubjectFactories - Class in org.onosproject.net.config.basics
Set of subject factories for potential configuration subjects.
subjectFactory() - Method in class org.onosproject.net.config.ConfigFactory
Returns the class of the subject to which this factory applies.
SubjectFactory<S> - Class in org.onosproject.net.config
Base abstract factory for creating configuration subjects from their string key image.
SubjectFactory(Class<S>, String) - Constructor for class org.onosproject.net.config.SubjectFactory
Creates a new configuration factory for the specified class of subjects capable of generating the configurations of the specified class.
subjectKey() - Method in exception org.onosproject.net.config.InvalidConfigException
Returns the subject key of the config.
subjectKey(S) - Method in class org.onosproject.net.config.SubjectFactory
Returns the unique key of the specified configuration subject.
SubjectKeyCompleter - Class in org.onosproject.cli.cfg
Network configuration subject key completer.
SubjectKeyCompleter() - Constructor for class org.onosproject.cli.cfg.SubjectKeyCompleter
 
subMap(String, String, boolean, boolean) - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
subMap(String, String, boolean, boolean) - Method in interface org.onosproject.store.service.AsyncConsistentTreeMap
Returns a navigable map containing the entries from the original map which are larger than (or if specified equal to) lowerKey AND less than (or if specified equal to) upperKey.
subMap(String, String, boolean, boolean) - Method in interface org.onosproject.store.service.ConsistentTreeMap
Returns a navigable map containing the entries from the original map which are larger than (or if specified equal to) lowerKey AND less than (or if specified equal to) upperKey.
submit(Runnable) - Method in class org.onlab.junit.NullScheduledExecutor
 
submit(Runnable) - Method in class org.onlab.util.BoundedThreadPool
 
submit(Runnable) - Method in class org.onlab.util.SharedScheduledExecutorService
 
submit(Runnable, int) - Method in class org.onlab.util.PredictableExecutor
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, Function<Runnable, Integer>) - Method in class org.onlab.util.PredictableExecutor
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in class org.onlab.junit.NullScheduledExecutor
 
submit(Runnable, T) - Method in class org.onlab.util.BoundedThreadPool
 
submit(Runnable, T) - Method in class org.onlab.util.SharedScheduledExecutorService
 
submit(Callable<T>) - Method in class org.onlab.junit.NullScheduledExecutor
 
submit(Callable<T>) - Method in class org.onlab.util.BoundedThreadPool
 
submit(Callable<T>) - Method in class org.onlab.util.SharedScheduledExecutorService
 
submit(Intent) - Static method in class org.onosproject.net.intent.IntentData
Creates IntentData for Intent submit request.
submit(Intent) - Method in interface org.onosproject.net.intent.IntentService
Submits an intent into the system.
submit(MeterRequest) - Method in interface org.onosproject.net.meter.MeterService
Adds a meter to the system and performs it installation.
SUBMIT - org.onosproject.net.intent.IntentOperation.Type
Indicates that an intent should be added.
subnetAddress() - Method in class org.onosproject.net.host.InterfaceIpAddress
Gets the IP subnet address.
subnetMask - Variable in class org.onlab.packet.RIPV2Entry
 
subnetMask() - Method in class org.onosproject.dhcp.IpAssignment
Returns subnet mask of the IP assignment.
subnetMask(Ip4Address) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
subscribe(Consumer<T>) - Method in interface org.onosproject.store.service.Topic
Subscribes to messages published to this topic.
subscribe(Consumer<T>, Executor) - Method in interface org.onosproject.store.service.Topic
Subscribes to messages published to this topic.
SUBSCRIBER_ID - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
SUBSCRIBER_ID - org.onlab.packet.DHCP6.OptionCode
 
subSequence(int, int) - Method in class org.onlab.util.XmlString
 
subtract(Weight) - Method in class org.onlab.graph.ScalarWeight
 
subtract(Weight) - Method in interface org.onlab.graph.Weight
Subtracts the given weight from this one and produces a new weight.
subtract(Bandwidth) - Method in interface org.onlab.util.Bandwidth
Returns a Bandwidth whose value is (this - value).
subtract(Frequency) - Method in class org.onlab.util.Frequency
Returns a Frequency whose value is (this - value).
subtype() - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction.ModOchSignalInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction.ModOduSignalIdInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModEtherInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsBosInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsHeaderInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsLabelInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsTtlInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModTunnelIdInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanHeaderInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanIdInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanPcpInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpEthInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpIPInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpOpInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModDscpInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPv6FlowLabelInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModTtlInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction
Returns the subtype of the modification instruction.
subtype() - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction.ModTransportPortInstruction
 
subtype() - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction
Returns the subtype of the modification instruction.
subType - Variable in class org.onlab.packet.LLDPOrganizationalTLV
 
SUBTYPE_LACP - Static variable in class org.onlab.packet.Slow
 
SUBTYPE_LENGTH - Static variable in class org.onlab.packet.LLDPOrganizationalTLV
 
success() - Static method in class org.onosproject.net.meter.MeterStoreResult
A successful store opertion.
SUCCESS - org.onosproject.net.behaviour.SoftwareUpgrade.Status
Indicates a successfully completed upgrade.
SUCCESS - org.onosproject.net.meter.MeterStoreResult.Type
 
SUCCESS - org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Means packet went through the pipeline.
SUCCESS - org.onosproject.store.service.CommitStatus
Indicates a successfully completed transaction with all the updates committed.
SUCCESS - Static variable in class org.onlab.packet.EAP
 
suggestedIdentifier() - Method in class org.onosproject.net.intent.constraint.EncapsulationConstraint
Returns the suggested identifier.
suggestedPath() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
Returns the suggestedPath of the intent.
suggestedPath() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
Returns the suggestedPath of the intent.
suggestedPath() - Method in class org.onosproject.net.intent.PointToPointIntent
Return the suggested path (as a list of links) that the compiler should use.
suggestedPath(List<Link>) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
Sets the suggested path as list of links.
suggestedPath(Optional<Path>) - Method in class org.onosproject.net.intent.OpticalCircuitIntent.Builder
Sets the suggestedPath of the intent.
suggestedPath(Optional<Path>) - Method in class org.onosproject.net.intent.OpticalConnectivityIntent.Builder
Sets the suggestedPath of the intent.
suggestIP(HostId, Ip4Address) - Method in interface org.onosproject.dhcp.DhcpStore
Returns an IP Address for a Mac ID, in response to a DHCP DISCOVER message.
sumbit(DomainIntent) - Method in interface org.onosproject.net.behaviour.DomainIntentConfigurable
Submit a intent in a network domain.
sumbit(DomainIntentOperations) - Method in interface org.onosproject.net.domain.DomainIntentService
Submit a batch operation of domain intent to be send to the target domain through the proper driver.
summarize(Iterable<Intent>, IntentService) - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Build summary of intents per intent type.
SUMMARY - Static variable in class org.onosproject.ui.GlyphConstants
 
SummaryCommand - Class in org.onosproject.cli
Provides summary of ONOS model.
SummaryCommand() - Constructor for class org.onosproject.cli.SummaryCommand
 
SummaryFlowEntryWithLoad - Class in org.onosproject.net.statistic
Summary Load classified by flow live type.
SummaryFlowEntryWithLoad(ConnectPoint, Load) - Constructor for class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Creates a new summary flow entry having load for the given connect point and total load.
SummaryFlowEntryWithLoad(ConnectPoint, Load, Load, Load, Load, Load) - Constructor for class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Creates a new summary flow entry having load for the given connect point and total, immediate, short, mid, and long load.
SummaryFlowEntryWithLoad(ConnectPoint, Load, Load, Load, Load, Load, Load) - Constructor for class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Creates a new summary flow entry having load for the given connect point and total, immediate, short, mid, long, and unknown load.
supportsAging() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns true if this table supports aging, false otherwise.
supportsFunctionality(IntProgrammable.IntFunctionality) - Method in interface org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable
Returns true if this device supports the given INT functionality.
SUPS_FIXED_PART_TOTAL_SIZE - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
suspend(HostId) - Method in interface org.onosproject.net.host.HostStore
Update the host to suspended state to true denotes host is in suspended state.
suspended() - Method in class org.onosproject.net.DefaultHost
 
suspended() - Method in interface org.onosproject.net.Host
Returns the state of host whether it is in suspended state(offending host due to frequent movement.).
SUSPENDED - org.onosproject.mastership.MastershipEvent.Type
Signifies that the underlying storage for the Mastership state of this device is unavailable.
SUSPENDED - org.onosproject.store.service.DistributedPrimitive.Status
Signifies a state wherein the primitive is temporarily incapable of providing the advertised consistency properties.
SuurballeGraphSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Suurballe shortest-path graph search algorithm capable of finding both a shortest path, as well as a backup shortest path, between a source and a destination such that the sum of the path lengths is minimized.
SuurballeGraphSearch() - Constructor for class org.onlab.graph.SuurballeGraphSearch
 
SW_VERSION - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
SWITCH - org.onosproject.net.Device.Type
 
SWITCH - Static variable in class org.onosproject.ui.GlyphConstants
 
SWITCH_ID - org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
ID of a switch, unique in the scope of the whole network.
switchToAutomatic(ConnectPoint) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Attempts to set the device to automatic protection mode.
switchToForce(ConnectPoint, int) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Attempts to forcibly switch to the one specified path by index.
switchToManual(ConnectPoint, int) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Attempts to manually switch to the one specified path by index.
swVersion() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device software version.
swVersion() - Method in class org.onosproject.net.DefaultDevice
 
swVersion() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
swVersion() - Method in interface org.onosproject.net.device.DeviceDescription
Returns the device software version.
swVersion() - Method in interface org.onosproject.net.Device
Returns the device software version.
swVersion() - Method in class org.onosproject.net.driver.DefaultDriver
 
swVersion() - Method in interface org.onosproject.net.driver.Driver
Returns the device software version.
swVersion() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
swVersion(String) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device software version.
SYN - org.onosproject.net.flow.criteria.Criterion.TcpFlags
Synchronize sequence numbers.
Synchronous<T extends DistributedPrimitive> - Class in org.onosproject.store.service
DistributedPrimitive that is a synchronous (blocking) version of another.
Synchronous(T) - Constructor for class org.onosproject.store.service.Synchronous
 
synthLinkCount() - Method in class org.onosproject.ui.model.topo.UiTopology
Returns the number of synthetic links in the topology.
SYS_CPU_TIME - org.onosproject.cpman.ControlMetricType
 
SYSTEM_IDENTIFIER_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet.SCI
 
SystemInfo - Interface in org.onosproject.cpman
System information interface.
SystemInfo.Builder - Interface in org.onosproject.cpman
A builder of SystemInfo.

T

table() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
table() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
table() - Method in interface org.onosproject.net.flow.FlowRule
Returns the table identifier for this rule.
table() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
Returns the table id.
table() - Method in interface org.onosproject.net.pi.model.PiCounterModel
Returns the table ID associated with this counter.
table() - Method in interface org.onosproject.net.pi.model.PiMeterModel
Returns the table model associated with this meter.
table() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
Returns the table where this entry is installed.
table(PiTableId) - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns the table model associated with the given ID, if present.
TABLE - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the traffic should be passed to another table.
TABLE - org.onosproject.net.PortNumber.Logical
 
TABLE - Static variable in class org.onosproject.net.PortNumber
 
TABLE_ENTRY - org.onosproject.net.pi.runtime.PiEntityType
Table entry.
TABLE_EXHAUSTED - org.onosproject.net.behaviour.upf.UpfProgrammableException.Type
The target table is at capacity.
tableEntry() - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
Returns the table entry to which this cell ID is associated.
tableEntry() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
Returns the table entry to which this cell ID is associated.
tableId() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
tableId() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
tableId() - Method in interface org.onosproject.net.flow.FlowRule
Deprecated.
in Loon release (version 1.11.0). Use FlowRule.table() instead.
tableId() - Method in class org.onosproject.net.flow.instructions.Instructions.TableTypeTransition
 
tableId() - Method in interface org.onosproject.net.flow.TableStatisticsEntry
Deprecated.
tableId() - Method in class org.onosproject.net.pi.runtime.PiGroupKey
Returns the table ID defined by this key.
tableId() - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
Returns the table ID associated with this handle.
TableId - Interface in org.onosproject.net.flow
Match+action table identifier.
TableId.Type - Enum in org.onosproject.net.flow
Types of table identifier.
TableModel - Class in org.onosproject.ui.table
A simple model of table data.
TableModel(String...) - Constructor for class org.onosproject.ui.table.TableModel
Constructs a table (devoid of data) with the given column IDs.
TableModel.Annot - Class in org.onosproject.ui.table
Model of an annotation.
TableModel.Row - Class in org.onosproject.ui.table
Model of a row.
TableModel.SortDir - Enum in org.onosproject.ui.table
Designates sorting direction.
TableRequestHandler - Class in org.onosproject.ui.table
Message handler specifically for table views.
TableRequestHandler(String, String, String) - Constructor for class org.onosproject.ui.table.TableRequestHandler
Constructs a table request handler for a specific table view.
tables() - Method in interface org.onosproject.net.pi.model.PiActionProfileModel
Returns the collection of table IDs that use this action profile.
tables() - Method in interface org.onosproject.net.pi.model.PiPipelineModel
Returns the collection of all table models defined by this pipeline model.
TableStatisticsCommand - Class in org.onosproject.cli.net
Lists port statistic of all ports in the system.
TableStatisticsCommand() - Constructor for class org.onosproject.cli.net.TableStatisticsCommand
 
TableStatisticsDiscovery - Interface in org.onosproject.net.behaviour
Behaviour capable of retrieving table statistics from device.
TableStatisticsEntry - Interface in org.onosproject.net.flow
Interface for flow table statistics of a device.
tableTransition() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
tableTransition() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the next table in the pipeline.
tableType() - Method in interface org.onosproject.net.pi.model.PiTableModel
Returns the type of this table.
TableUtils - Class in org.onosproject.ui.table
Provides static utility methods for dealing with tables.
tags - Variable in class org.onlab.packet.PPPoED
 
take() - Method in interface org.onosproject.store.service.WorkQueue
Picks up a single task from the work queue to work on.
take(int) - Method in interface org.onosproject.store.service.WorkQueue
Picks up multiple tasks from the work queue to work on.
target() - Method in class org.onosproject.net.behaviour.ControllerInfo
Deprecated.
target() - Method in class org.onosproject.net.flow.BatchOperationEntry
Gets the target object of this operation.
target() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the target IP address of the message.
target() - Method in class org.onosproject.upgrade.Upgrade
Returns the target version.
targetAddress - Variable in class org.onlab.packet.ndp.NeighborAdvertisement
 
targetAddress - Variable in class org.onlab.packet.ndp.NeighborSolicitation
 
targetAddress - Variable in class org.onlab.packet.ndp.Redirect
 
targetAddress() - Method in class org.onosproject.net.flow.criteria.IPv6NDTargetAddressCriterion
Gets the IPv6 target address to match.
targetHardwareAddress - Variable in class org.onlab.packet.ARP
 
targetProtocolAddress - Variable in class org.onlab.packet.ARP
 
TarjanGraphSearch<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Tarjan algorithm for searching a graph and producing results describing the graph SCC (strongly-connected components).
TarjanGraphSearch() - Constructor for class org.onlab.graph.TarjanGraphSearch
 
TarjanGraphSearch.SccResult<V extends Vertex,​E extends Edge<V>> - Class in org.onlab.graph
Graph search result augmented with SCC vertexData.
Task<E> - Class in org.onosproject.store.service
WorkQueue task.
Task(String, E) - Constructor for class org.onosproject.store.service.Task
Constructs a new task instance.
taskId() - Method in class org.onosproject.store.service.Task
Returns the task identifier.
tc() - Method in class org.onosproject.net.flow.criteria.MplsTcCriterion
Gets the MPLS TC to match.
TCP - Class in org.onlab.packet
Implements TCP packet format.
TCP - org.onosproject.cli.net.IpProtocol
TCP.
TCP() - Constructor for class org.onlab.packet.TCP
 
TCP_DST - org.onosproject.net.flow.criteria.Criterion.Type
TCP destination port.
TCP_DST - org.onosproject.net.flow.instructions.L4ModificationInstruction.L4SubType
TCP dst modification.
TCP_DST_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
TCP destination port with masking.
TCP_FLAGS - org.onosproject.net.flow.criteria.Criterion.Type
TCP flags.
TCP_SRC - org.onosproject.net.flow.criteria.Criterion.Type
TCP source port.
TCP_SRC - org.onosproject.net.flow.instructions.L4ModificationInstruction.L4SubType
TCP src modification.
TCP_SRC_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
TCP source port with masking.
TcpFlagsCriterion - Class in org.onosproject.net.flow.criteria
Implementation of TCP flags criterion (12 bits unsigned integer).
tcpPort() - Method in class org.onosproject.cluster.DefaultControllerNode
 
tcpPort() - Method in interface org.onosproject.cluster.Node
Returns the TCP port on which the node listens for connections.
tcpPort() - Method in class org.onosproject.net.flow.criteria.TcpPortCriterion
Gets the TCP port to match.
TcpPortCriterion - Class in org.onosproject.net.flow.criteria
Implementation of TCP port criterion (16 bits unsigned integer).
teid() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Get the identifier of the GTP tunnel that this FAR will encapsulate packets with.
teid() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
Get the ID of this unidirectional GTP tunnel.
teid() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Get the identifier of the GTP tunnel that this PDR matches on.
TENANT_ID_COMPARATOR - Static variable in class org.onosproject.utils.Comparators
 
tenantId(String) - Static method in class org.onosproject.net.TenantId
Creates a tenant id using the supplied backing id.
TenantId - Class in org.onosproject.net
Representation of network tenant.
TenantId() - Constructor for class org.onosproject.net.TenantId
 
term() - Method in class org.onosproject.cluster.Leader
Returns the leader's term.
term() - Method in class org.onosproject.mastership.MastershipInfo
Returns the mastership term.
term() - Method in class org.onosproject.store.flow.ReplicaInfo
Returns the mastership term.
term() - Method in class org.onosproject.store.service.PartitionInfo
Returns the term number.
TERMINAL_DEVICE - org.onosproject.net.Device.Type
 
termNumber() - Method in class org.onosproject.mastership.MastershipTerm
 
termStartTime() - Method in class org.onosproject.cluster.Leader
Returns the system time when the current leadership term started.
TERNARY - org.onosproject.net.pi.model.PiMatchType
Ternary match type.
TestAllocateResource - Class in org.onosproject.cli.net
Test tool to allocate resources.
TestAllocateResource() - Constructor for class org.onosproject.cli.net.TestAllocateResource
 
testConnectivity(PortNumber, PortNumber) - Method in interface org.onosproject.net.behaviour.InternalConnectivity
Test if two ports of the device can be internally connected.
TestProtectionEndpointIntentCommand - Class in org.onosproject.cli.net
Test tool to add ProtectionEndpointIntent.
TestProtectionEndpointIntentCommand() - Constructor for class org.onosproject.cli.net.TestProtectionEndpointIntentCommand
 
TestTools - Class in org.onlab.junit
Utilities to aid in producing JUnit tests.
TestUtils - Class in org.onlab.junit
Utilities for testing.
TestUtils.TestUtilsException - Exception in org.onlab.junit
Exception that can be thrown if problems are encountered while executing the utility method.
TestUtilsException(String, Throwable) - Constructor for exception org.onlab.junit.TestUtils.TestUtilsException
Constructs a new exception with the specified detail message and cause.
text() - Method in class org.onosproject.ui.topo.NodeBadge
Returns the text for the badge.
text(String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns an arbitrary text badge, with default status.
text(NodeBadge.Status, String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns an arbitrary text badge, with the given status.
text(NodeBadge.Status, String, String) - Static method in class org.onosproject.ui.topo.NodeBadge
Returns an arbitrary text badge, with the given status and optional message.
thenAccept(Consumer<? super T>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenAcceptAsync(Consumer<? super T>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenAcceptAsync(Consumer<? super T>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
thenApply(Function<? super T, ? extends U>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenApplyAsync(Function<? super T, ? extends U>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in class org.onlab.util.BlockingAwareFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
thenRun(Runnable) - Method in class org.onlab.util.BlockingAwareFuture
 
thenRunAsync(Runnable) - Method in class org.onlab.util.BlockingAwareFuture
 
thenRunAsync(Runnable, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
threadGroup() - Method in class org.onlab.util.GroupedThreadFactory
Returns the thread group associated with the factory.
threshold() - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
Returns the threshold this constraint ensures as link annotated value.
throughput() - Method in class org.onlab.util.Counter
Returns the number of occurrences per second.
tier() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns link tier.
tier(Long) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link tier.
TIER - org.onosproject.net.intent.constraint.TierConstraint.CostType
Configures the constraint to return the tier value as the cost.
TIER - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for identifying the tier ranking of a link.
TIER - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
TierConstraint - Class in org.onosproject.net.intent.constraint
Constraint that evaluates links based on their type.
TierConstraint(boolean, Integer...) - Constructor for class org.onosproject.net.intent.constraint.TierConstraint
Creates a new constraint for requesting connectivity using or avoiding the specified link tiers.
TierConstraint(boolean, TierConstraint.CostType, Integer...) - Constructor for class org.onosproject.net.intent.constraint.TierConstraint
Creates a new constraint for requesting connectivity using or avoiding the specified link tiers.
TierConstraint.CostType - Enum in org.onosproject.net.intent.constraint
 
tiers() - Method in class org.onosproject.net.intent.constraint.TierConstraint
Returns the set of link tiers.
time() - Method in class org.onosproject.common.DefaultTopology
 
time() - Method in class org.onosproject.core.HybridLogicalTime
Returns the real system time represented by this HLT.
time() - Method in class org.onosproject.cpman.ControlLoadSnapshot
Returns last logging time of control metric.
time() - Method in class org.onosproject.event.AbstractEvent
 
time() - Method in interface org.onosproject.event.Event
Returns the timestamp of when the event occurred, given in milliseconds since the start of epoch.
time() - Method in interface org.onosproject.net.behaviour.BasicSystemOperations
Returns the current time on the target.
time() - Method in class org.onosproject.net.HostLocation
Returns the time when the location was established, given in milliseconds since start of epoch.
time() - Method in class org.onosproject.net.packet.DefaultPacketContext
 
time() - Method in interface org.onosproject.net.packet.PacketContext
Returns the time when the packet was received.
time() - Method in class org.onosproject.net.statistic.DefaultLoad
 
time() - Method in interface org.onosproject.net.statistic.Load
Returns when this value was seen.
time() - Method in interface org.onosproject.net.topology.Topology
Returns the time, specified in system nanos of when the topology became available.
TIME_EXCEED - org.onosproject.cli.net.Icmp6Type
Time Exceeded.
TIME_EXCEED - Static variable in class org.onlab.packet.ICMP6
Time Exceeded.
timeAgo(long) - Static method in class org.onlab.util.Tools
Returns a human friendly time ago string for a specified system time.
timeCleared() - Method in interface org.onosproject.alarm.Alarm
Returns the time when cleared.
timeCleared() - Method in class org.onosproject.alarm.DefaultAlarm
 
TimeFormatter - Class in org.onosproject.ui.table.cell
Formats time values using DateTimeFormatter.
TimeFormatter() - Constructor for class org.onosproject.ui.table.cell.TimeFormatter
Constructs a time formatter that uses the default locale and timezone.
timeNow() - Method in interface org.onosproject.core.HybridLogicalClockService
Returns the current hybrid logical time.
timeout() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
timeout() - Method in interface org.onosproject.net.flow.FlowRule
Returns the timeout for this flow requested by an application.
timeout() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
timeout() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
timeout() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
timeout() - Method in interface org.onosproject.net.flowobjective.Objective
The timeout for this objective.
timeout() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
Returns the timeout in seconds of this table entry, if present.
Timeout() - Constructor for exception org.onosproject.net.flow.FlowRuleStoreException.Timeout
 
Timeout() - Constructor for exception org.onosproject.store.service.ConsistentMapException.Timeout
 
Timeout() - Constructor for exception org.onosproject.store.service.DocumentException.Timeout
 
Timeout() - Constructor for exception org.onosproject.store.service.StorageException.Timeout
 
Timeout() - Constructor for exception org.onosproject.store.service.TransactionException.Timeout
 
Timeout(String) - Constructor for exception org.onosproject.store.service.ConsistentMapException.Timeout
 
Timeout(String) - Constructor for exception org.onosproject.store.service.DocumentException.Timeout
 
Timeout(String, Throwable) - Constructor for exception org.onosproject.store.service.DocumentException.Timeout
 
Timeout(Throwable) - Constructor for exception org.onosproject.store.service.DocumentException.Timeout
 
TIMEOUT - org.onosproject.net.meter.MeterFailReason
The operation for this meter installation timed out.
TIMEOUT_MILLIS - Static variable in interface org.onosproject.cpman.ControlPlaneMonitorService
 
TIMEOUT_MILLIS - Static variable in interface org.onosproject.mastership.MastershipAdminService
 
TIMEOUT_MILLIS - Static variable in interface org.onosproject.mastership.MastershipService
 
timer() - Method in class org.onlab.util.AbstractAccumulator
Returns the backing timer.
Timer - Class in org.onlab.util
Hashed-wheel timer singleton.
timeRaised() - Method in interface org.onosproject.alarm.Alarm
Returns the time when raised.
timeRaised() - Method in class org.onosproject.alarm.DefaultAlarm
 
timestamp() - Method in interface org.onosproject.cpman.ControlMessage
Returns the time that this control message stats collected.
timestamp() - Method in class org.onosproject.cpman.DefaultControlMessage
 
timestamp() - Method in class org.onosproject.dhcp.IpAssignment
Returns the timestamp of the IP assignment.
timestamp() - Method in class org.onosproject.net.topology.DefaultGraphDescription
 
timestamp() - Method in interface org.onosproject.net.topology.GraphDescription
Returns the creation timestamp of the graph description.
timestamp(Date) - Method in class org.onosproject.dhcp.IpAssignment.Builder
 
Timestamp - Interface in org.onosproject.store
Opaque version structure.
TIMESTAMP_SUBTYPE - Static variable in class org.onlab.packet.ONOSLLDP
 
timeUpdated() - Method in interface org.onosproject.alarm.Alarm
Returns time at which the alarm was updated most recently, due to some change in the device, or ONOS.
timeUpdated() - Method in class org.onosproject.alarm.DefaultAlarm
 
title() - Method in interface org.onosproject.app.ApplicationDescription
Returns title of the application.
title() - Method in class org.onosproject.app.DefaultApplicationDescription
 
title() - Method in interface org.onosproject.core.Application
Returns the title of the application.
title() - Method in class org.onosproject.core.DefaultApplication
 
title() - Method in class org.onosproject.ui.topo.PropertyPanel
Returns the title text.
title(String) - Method in class org.onosproject.ui.topo.PropertyPanel
Sets the title text.
TO_5DP - Static variable in class org.onosproject.ui.table.cell.NumberFormatter
An instance of this class that formats to 5 decimal places.
toArray() - Method in class org.onlab.util.ExtendedSet
 
toArray() - Method in class org.onlab.util.UnmodifiableDeque
 
toArray() - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
toArray(T[]) - Method in class org.onlab.util.ExtendedSet
 
toArray(T[]) - Method in class org.onlab.util.UnmodifiableDeque
 
toArray(T[]) - Method in class org.onosproject.store.primitives.DefaultDistributedSet
 
toBit(boolean, int) - Static method in class org.onlab.util.ByteOperator
Converts boolean value into bit.
toBitsPerSecond(double) - Method in enum org.onlab.util.DataRateUnit
Converts given value in this unit to bits per seconds.
toBitsPerSecond(long) - Method in enum org.onlab.util.DataRateUnit
Converts given value in this unit to bits per seconds.
toByte() - Method in class org.onlab.packet.lacp.LacpState
Gets LACP state in byte.
toByteArray(long) - Static method in class org.onlab.packet.Ethernet
Converts a long MAC address to a byte array.
toBytes() - Method in class org.onlab.packet.MacAddress
Returns the value of the MACAddress as a byte array.
toCompactListString() - Method in class org.onosproject.ui.topo.LayoutLocation
Produces a compact string representation of this instance.
toCompactListString(List<LayoutLocation>) - Static method in class org.onosproject.ui.topo.LayoutLocation
Produces a compact encoding of a list of layout locations.
toCompactListString(LayoutLocation...) - Static method in class org.onosproject.ui.topo.LayoutLocation
Produces a compact encoding of a list of layout locations.
toEqualsBuilder(Port) - Method in class org.onosproject.net.utils.ForwardingPort
Returns EqualsBuilder comparing all Port attributes including annotations.
TOFINO_BIN - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Barefoot's Tofino configuration binary.
TOFINO_CONTEXT_JSON - org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Barefoot's Tofino context JSON.
toFixedGrid(List<OchSignal>, ChannelSpacing) - Static method in class org.onosproject.net.OchSignal
Convert list of lambdas with flex grid 6.25 GHz spacing and 12.5 GHz width into fixed grid OCh signal.
toFlexGrid(OchSignal) - Static method in class org.onosproject.net.OchSignal
Convert fixed grid OCh signal to sorted set of flex grid slots with 6.25 GHz spacing and 12.5 GHz slot width.
toHex(long) - Static method in class org.onlab.util.Tools
Converts a long value to hex string; 16 wide and sans 0x.
toHex(long, int) - Static method in class org.onlab.util.Tools
Converts a long value to hex string; 16 wide and sans 0x.
toHexString(byte[]) - Static method in class org.onlab.util.HexString
Convert a byte array to a colon-separated hex string.
toHexString(byte[], String) - Static method in class org.onlab.util.HexString
Convert a byte array to a hex string separated by given separator.
toHexString(long) - Static method in class org.onlab.util.HexString
Convert a long number to colon-separated hex string.
toHexString(long, int) - Static method in class org.onlab.util.HexString
Convert a long number to colon-separated hex string.
toHexWithPrefix(long) - Static method in class org.onlab.util.Tools
Returns a string encoding in hex of the given long value with prefix '0x'.
toImmutable() - Method in class org.onlab.graph.DefaultMutablePath
 
toImmutable() - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
toImmutable() - Method in interface org.onlab.graph.MutableGraph
Returns an immutable copy of this graph.
toImmutable() - Method in interface org.onlab.graph.MutablePath
Returns an immutable copy of this path.
toImmutableList() - Static method in class org.onlab.util.GuavaCollectors
Deprecated.
in 1.11.0 consider using ImmutableList.toImmutableList() instead.
toImmutableSet() - Static method in class org.onlab.util.GuavaCollectors
Deprecated.
in 1.11.0 consider using ImmutableSet.toImmutableSet() instead.
toInetAddress() - Method in class org.onlab.packet.IpAddress
Returns the IP address as InetAddress.
toInstall() - Method in class org.onosproject.net.intent.IntentInstallationContext
Retrieves the Intent data which to be installed.
toInstall() - Method in class org.onosproject.net.intent.IntentOperationContext
Retrieves high level Intent data to install.
toInt() - Method in class org.onlab.packet.Ip4Address
Returns the integer value of this IPv4 address.
toInt() - Method in class org.onlab.packet.MplsLabel
 
toInt() - Method in class org.onlab.packet.TpPort
Returns the integer value for this transport port.
toInt() - Method in class org.onosproject.core.Version
Returns an integer representation of the version.
toInt() - Method in class org.onosproject.net.flow.criteria.ExtensionSelectorType
Returns the integer value associated with this type.
toIpPrefix() - Method in class org.onlab.packet.IpAddress
Generates an IP prefix.
toIPv4Address(byte[]) - Static method in class org.onlab.packet.IPv4
Accepts an IPv4 address in a byte array and returns the corresponding 32-bit integer value.
toIPv4Address(String) - Static method in class org.onlab.packet.IPv4
Accepts an IPv4 address of the form xxx.xxx.xxx.xxx, ie 192.168.0.1 and returns the corresponding 32 bit integer.
toIPv4AddressBytes(int) - Static method in class org.onlab.packet.IPv4
Accepts an IPv4 address in the form of an integer and returns the corresponding byte array.
toIPv4AddressBytes(String) - Static method in class org.onlab.packet.IPv4
Accepts an IPv4 address of the form xxx.xxx.xxx.xxx, ie 192.168.0.1 and returns the corresponding byte array.
toJsonNode(ChartModel.DataPoint, ChartModel) - Static method in class org.onosproject.ui.chart.ChartUtils
Generate a JSON node from the data point and given chart model.
TokenBucket - Interface in org.onosproject.net.behaviour.trafficcontrol
Generic abstraction for a token bucket which can mark and/or discard traffic.
TokenBucket.Action - Enum in org.onosproject.net.behaviour.trafficcontrol
Action applied to the exceeding traffic.
TokenBucket.Builder - Interface in org.onosproject.net.behaviour.trafficcontrol
Token bucket builder.
TokenBucket.Type - Enum in org.onosproject.net.behaviour.trafficcontrol
Token bucket type.
TokenBucketEntry - Interface in org.onosproject.net.behaviour.trafficcontrol
Represents a stored token bucket.
tokenBuckets() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
tokenBuckets() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
The token buckets used within this policer.
toLong() - Method in class org.onlab.packet.MacAddress
Returns the value of the MACAddress as a long.
toLong() - Method in class org.onosproject.net.PortNumber
Returns the backing long value.
toLong(byte[]) - Static method in class org.onlab.packet.Ethernet
Accepts a MAC address and returns the corresponding long, where the MAC bytes are set on the lower order bytes of the long.
toLong(String) - Static method in class org.onlab.util.HexString
Convert a colon-separated hex string to long.
toMACAddress(String) - Static method in class org.onlab.packet.Ethernet
Accepts a MAC address of the form 00:aa:11:bb:22:cc, case does not matter, and returns a corresponding byte[].
toNodeId() - Static method in class org.onosproject.cluster.ControllerNodeToNodeId
Returns a Function to convert ControllerNode to NodeId.
TOO_SHORT - Static variable in class org.onosproject.core.Version
 
toOctets() - Method in class org.onlab.packet.IpAddress
Returns the IP address as a byte array.
Tools - Class in org.onlab.util
Miscellaneous utility methods.
Tools.LogLevel - Enum in org.onlab.util
Log level for the customized logger.
topic() - Method in class org.onosproject.cluster.Leadership
Returns the leadership topic.
Topic<T> - Interface in org.onosproject.store.service
A distributed publish subscribe primitive.
TOPIC - org.onosproject.store.service.DistributedPrimitive.Type
Distributed topic.
topicBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new TopicBuilder.
topicBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new TopicBuilder.
TopicBuilder<T> - Class in org.onosproject.store.service
Builder for Topic instances.
TopicBuilder() - Constructor for class org.onosproject.store.service.TopicBuilder
 
TopicOptions<O extends TopicOptions<O,​T>,​T> - Class in org.onosproject.store.service
Builder for Topic instances.
TopicOptions() - Constructor for class org.onosproject.store.service.TopicOptions
 
TOPO - Static variable in class org.onosproject.ui.GlyphConstants
 
topo2HighlightsMessage(Highlights) - Static method in class org.onosproject.ui.topo.TopoJson
Returns a formatted message ready to send to the topology-2 view to render highlights.
topo2OverlayFactory() - Method in class org.onosproject.ui.UiExtension
Returns the topology-2 overlay factory, if one was defined.
topo2OverlayFactory(UiTopo2OverlayFactory) - Method in class org.onosproject.ui.UiExtension.Builder
Sets the topology-2 overlay factory for this extension.
TopoConstants - Class in org.onosproject.ui.topo
Defines string constants used in the Topology View of the ONOS GUI.
TopoConstants() - Constructor for class org.onosproject.ui.topo.TopoConstants
 
TopoConstants.CoreButtons - Class in org.onosproject.ui.topo
Defines identities of core buttons that appear on the topology details panel.
TopoConstants.Properties - Class in org.onosproject.ui.topo
Defines constants for property/localization keys on the default summary and details panels.
TopoElementType - Enum in org.onosproject.ui.topo
The topology element types to which a highlight can be applied.
TopoJson - Class in org.onosproject.ui.topo
JSON utilities for the Topology View.
topology - Variable in class org.onosproject.cli.net.TopologyCommand
 
topology - Variable in class org.onosproject.ui.model.topo.UiLink
 
Topology - Interface in org.onosproject.net.topology
Represents a network topology computation snapshot.
TOPOLOGY_CHANGED - org.onosproject.net.topology.TopologyEvent.Type
Signifies that topology has changed.
TOPOLOGY_EVENT - org.onosproject.security.AppPermission.Type
 
TOPOLOGY_READ - org.onosproject.security.AppPermission.Type
 
TOPOLOGY_SSCS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
topologyChanged(GraphDescription, List<Event>) - Method in interface org.onosproject.net.topology.TopologyProviderService
Signals the core that some aspect of the topology has changed.
TopologyChangeDelegate - Interface in org.onosproject.net.intent
Auxiliary delegate for integration of intent manager and flow trackerService.
TopologyCluster - Interface in org.onosproject.net.topology
Representation of an SCC (strongly-connected component) in a network topology.
TopologyCommand - Class in org.onosproject.cli.net
Lists summary of the current topology.
TopologyCommand() - Constructor for class org.onosproject.cli.net.TopologyCommand
 
TopologyEdge - Interface in org.onosproject.net.topology
Represents an edge in the topology graph.
TopologyEvent - Class in org.onosproject.net.topology
Describes network topology event.
TopologyEvent(TopologyEvent.Type, Topology, List<Event>) - Constructor for class org.onosproject.net.topology.TopologyEvent
Creates an event of a given type and for the specified topology and the current time.
TopologyEvent(TopologyEvent.Type, Topology, List<Event>, long) - Constructor for class org.onosproject.net.topology.TopologyEvent
Creates an event of a given type and for the specified topology and time.
TopologyEvent.Type - Enum in org.onosproject.net.topology
Type of topology events.
TopologyGraph - Interface in org.onosproject.net.topology
Represents an immutable topology graph.
TopologyListener - Interface in org.onosproject.net.topology
Entity capable of receiving network topology related events.
TopologyProvider - Interface in org.onosproject.net.topology
Means for injecting topology information into the core.
TopologyProviderRegistry - Interface in org.onosproject.net.topology
Abstraction of a network topology provider registry.
TopologyProviderService - Interface in org.onosproject.net.topology
Means for injecting topology information into the core.
topologyService - Variable in class org.onosproject.net.topology.AbstractPathService
 
TopologyService - Interface in org.onosproject.net.topology
Service for providing network topology information.
TopologyStore - Interface in org.onosproject.net.topology
Manages inventory of topology snapshots; not intended for direct use.
TopologyStoreDelegate - Interface in org.onosproject.net.topology
Topology store delegate abstraction.
TopologyVertex - Interface in org.onosproject.net.topology
Represents a vertex in the topology graph.
topoMapFactory() - Method in class org.onosproject.ui.UiExtension
Returns the topology map factory, if one was defined.
topoMapFactory(UiTopoMapFactory) - Method in class org.onosproject.ui.UiExtension.Builder
Sets the topology map factory for this extension.
topoOverlayFactory() - Method in class org.onosproject.ui.UiExtension
Returns the topology overlay factory, if one was defined.
topoOverlayFactory(UiTopoOverlayFactory) - Method in class org.onosproject.ui.UiExtension.Builder
Sets the topology overlay factory for this extension.
TopoUtils - Class in org.onosproject.ui.topo
Utility methods for helping out with formatting data for the Topology View in the web client.
TopoUtils.Magnitude - Enum in org.onosproject.ui.topo
Enumeration of magnitudes.
TopoUtils.ValueLabel - Class in org.onosproject.ui.topo
Encapsulates a value to be used as a label.
toResponse(E) - Method in class org.onlab.rest.exceptions.AbstractMapper
 
toResponse(WebApplicationException) - Method in class org.onlab.rest.exceptions.WebApplicationExceptionMapper
Extracts and returns the response from a WebApplicationException.
toShort() - Method in class org.onlab.packet.EthType
Returns the short value for this ethtype.
toShort() - Method in class org.onlab.packet.VlanId
Returns the backing VLAN number.
toString() - Method in class org.onlab.graph.AbstractEdge
 
toString() - Method in class org.onlab.graph.AdjacencyListsGraph
 
toString() - Method in class org.onlab.graph.DefaultMutablePath
 
toString() - Method in class org.onlab.graph.DefaultPath
 
toString() - Method in class org.onlab.graph.DisjointPathPair
 
toString() - Method in class org.onlab.graph.Heap
 
toString() - Method in class org.onlab.graph.MutableAdjacencyListsGraph
 
toString() - Method in class org.onlab.graph.ScalarWeight
 
toString() - Method in class org.onlab.packet.ARP
 
toString() - Method in class org.onlab.packet.bmp.Bmp
 
toString() - Method in class org.onlab.packet.bmp.BmpPeer
 
toString() - Method in class org.onlab.packet.ChassisId
Convert the Chassis Id value to a ':' separated hexadecimal string.
toString() - Method in class org.onlab.packet.Data
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6ClientDataOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6ClientIdOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6CLTOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6Duid
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6IaAddressOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6IaNaOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6IaPdOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6IaPrefixOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6IaTaOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6InterfaceIdOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6LeaseQueryOption
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6Option
 
toString() - Method in class org.onlab.packet.dhcp.Dhcp6RelayOption
 
toString() - Method in class org.onlab.packet.dhcp.DhcpOption
 
toString() - Method in class org.onlab.packet.DHCP
 
toString() - Method in class org.onlab.packet.DHCP6
 
toString() - Method in class org.onlab.packet.EAP
 
toString() - Method in class org.onlab.packet.EAPOL
 
toString() - Method in class org.onlab.packet.Ethernet
 
toString() - Method in enum org.onlab.packet.EthType.EtherType
 
toString() - Method in class org.onlab.packet.EthType
 
toString() - Method in class org.onlab.packet.ICMP
 
toString() - Method in class org.onlab.packet.ICMP6
 
toString() - Method in class org.onlab.packet.ICMPEcho
 
toString() - Method in class org.onlab.packet.IGMP
 
toString() - Method in class org.onlab.packet.IGMPGroup
 
toString() - Method in class org.onlab.packet.IpAddress
 
toString() - Method in class org.onlab.packet.IpPrefix
 
toString() - Method in class org.onlab.packet.IPv4
 
toString() - Method in class org.onlab.packet.ipv6.Authentication
 
toString() - Method in class org.onlab.packet.ipv6.BaseOptions
 
toString() - Method in class org.onlab.packet.ipv6.EncapSecurityPayload
 
toString() - Method in class org.onlab.packet.ipv6.Fragment
 
toString() - Method in class org.onlab.packet.ipv6.Routing
 
toString() - Method in class org.onlab.packet.IPv6
 
toString() - Method in class org.onlab.packet.lacp.Lacp
 
toString() - Method in class org.onlab.packet.lacp.LacpBaseTlv
 
toString() - Method in class org.onlab.packet.lacp.LacpCollectorTlv
 
toString() - Method in class org.onlab.packet.lacp.LacpState
 
toString() - Method in class org.onlab.packet.lacp.LacpTerminatorTlv
 
toString() - Method in class org.onlab.packet.LLC
 
toString() - Method in class org.onlab.packet.LLDP
 
toString() - Method in class org.onlab.packet.LLDPTLV
 
toString() - Method in class org.onlab.packet.MacAddress
 
toString() - Method in class org.onlab.packet.MPLS
 
toString() - Method in class org.onlab.packet.MplsLabel
 
toString() - Method in class org.onlab.packet.ndp.NeighborAdvertisement
 
toString() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions.Option
 
toString() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
toString() - Method in class org.onlab.packet.ndp.NeighborSolicitation
 
toString() - Method in class org.onlab.packet.ndp.Redirect
 
toString() - Method in class org.onlab.packet.ndp.RouterAdvertisement
 
toString() - Method in class org.onlab.packet.ndp.RouterSolicitation
 
toString() - Method in class org.onlab.packet.pim.PIMHello
 
toString() - Method in class org.onlab.packet.pim.PIMHelloOption
 
toString() - Method in class org.onlab.packet.pim.PIMJoinPrune
 
toString() - Method in class org.onlab.packet.PIM
 
toString() - Method in class org.onlab.packet.PPPoED
 
toString() - Method in class org.onlab.packet.PPPoEDTag
 
toString() - Method in class org.onlab.packet.RADIUS
 
toString() - Method in class org.onlab.packet.RADIUSAttribute
 
toString() - Method in class org.onlab.packet.RIP
 
toString() - Method in class org.onlab.packet.RIPng
 
toString() - Method in class org.onlab.packet.RIPngEntry
 
toString() - Method in class org.onlab.packet.RIPV2AuthEntry
 
toString() - Method in class org.onlab.packet.RIPV2Entry
 
toString() - Method in class org.onlab.packet.Slow
 
toString() - Method in class org.onlab.packet.TCP
 
toString() - Method in class org.onlab.packet.TpPort
 
toString() - Method in class org.onlab.packet.UDP
 
toString() - Method in class org.onlab.packet.VlanId
 
toString() - Method in class org.onlab.packet.VXLAN
 
toString() - Method in class org.onlab.util.ByteArraySizeHashPrinter
 
toString() - Method in class org.onlab.util.ClosedOpenRange
 
toString() - Method in class org.onlab.util.Counter
 
toString() - Method in class org.onlab.util.Frequency
 
toString() - Method in class org.onlab.util.GeoLocation
 
toString() - Method in class org.onlab.util.GroupedThreadFactory
 
toString() - Method in class org.onlab.util.Identifier
Returns a string representation of a DeviceKeyId.
toString() - Method in class org.onlab.util.ImmutableByteSequence
Returns the ASCII representation of the byte sequence if the content can be interpreted as an ASCII string, otherwise returns the hexadecimal representation of this byte sequence, e.g.0xbeef.
toString() - Method in class org.onlab.util.KryoNamespace
 
toString() - Method in class org.onlab.util.Match
 
toString() - Method in class org.onlab.util.UnmodifiableDeque
 
toString() - Method in class org.onlab.util.XmlString
 
toString() - Method in class org.onosproject.alarm.DefaultAlarm
 
toString() - Method in class org.onosproject.app.DefaultApplicationDescription
 
toString() - Method in class org.onosproject.cfg.ConfigProperty
 
toString() - Method in class org.onosproject.cluster.ClusterEvent
 
toString() - Method in class org.onosproject.cluster.ClusterMetadata
 
toString() - Method in class org.onosproject.cluster.ClusterMetadataEvent
 
toString() - Method in class org.onosproject.cluster.DefaultControllerNode
 
toString() - Method in class org.onosproject.cluster.DefaultPartition
 
toString() - Method in class org.onosproject.cluster.Leader
 
toString() - Method in class org.onosproject.cluster.Leadership
 
toString() - Method in class org.onosproject.cluster.LeadershipEvent
 
toString() - Method in class org.onosproject.cluster.Member
 
toString() - Method in class org.onosproject.cluster.MembershipGroup
 
toString() - Method in class org.onosproject.cluster.PartitionDiff
 
toString() - Method in class org.onosproject.cluster.RoleInfo
 
toString() - Method in class org.onosproject.common.DefaultTopology
 
toString() - Method in class org.onosproject.core.DefaultApplication
 
toString() - Method in class org.onosproject.core.DefaultApplicationId
 
toString() - Method in class org.onosproject.core.GroupId
 
toString() - Method in class org.onosproject.core.HybridLogicalTime
 
toString() - Method in class org.onosproject.core.IdBlock
 
toString() - Method in class org.onosproject.core.Version
 
toString() - Method in class org.onosproject.cpman.ControlLoadSnapshot
 
toString() - Method in class org.onosproject.cpman.ControlMetricsRequest
 
toString() - Method in class org.onosproject.cpman.ControlResourceRequest
 
toString() - Method in class org.onosproject.cpman.DefaultControlMessage
 
toString() - Method in class org.onosproject.cpman.message.ControlMessageEvent
 
toString() - Method in class org.onosproject.cpman.MetricValue
 
toString() - Method in class org.onosproject.dhcp.IpAssignment
 
toString() - Method in class org.onosproject.event.AbstractEvent
 
toString() - Method in class org.onosproject.event.Change
 
toString() - Method in class org.onosproject.mastership.MastershipEvent
 
toString() - Method in class org.onosproject.mastership.MastershipInfo
 
toString() - Method in class org.onosproject.mastership.MastershipTerm
 
toString() - Method in class org.onosproject.net.behaviour.BandwidthProfile
 
toString() - Method in class org.onosproject.net.behaviour.BandwidthProfileAction
 
toString() - Method in class org.onosproject.net.behaviour.BridgeName
 
toString() - Method in enum org.onosproject.net.behaviour.ControlProtocolVersion
 
toString() - Method in class org.onosproject.net.behaviour.DefaultMirroringDescription
 
toString() - Method in class org.onosproject.net.behaviour.DefaultPatchDescription
 
toString() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
toString() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
toString() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
toString() - Method in class org.onosproject.net.behaviour.DeviceCpuStats
 
toString() - Method in class org.onosproject.net.behaviour.DeviceMemoryStats
 
toString() - Method in class org.onosproject.net.behaviour.DeviceSystemStats
 
toString() - Method in class org.onosproject.net.behaviour.MirroringName
 
toString() - Method in class org.onosproject.net.behaviour.MirroringStatistics
 
toString() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointDescription
 
toString() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
 
toString() - Method in class org.onosproject.net.behaviour.protection.ProtectionConfig
 
toString() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription
 
toString() - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState
 
toString() - Method in class org.onosproject.net.behaviour.QosId
 
toString() - Method in class org.onosproject.net.behaviour.QueueId
 
toString() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
toString() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
toString() - Method in class org.onosproject.net.behaviour.trafficcontrol.PolicingResource
 
toString() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
 
toString() - Method in class org.onosproject.net.behaviour.upf.GtpTunnel
 
toString() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
 
toString() - Method in class org.onosproject.net.behaviour.upf.PdrStats
 
toString() - Method in class org.onosproject.net.behaviour.upf.UpfInterface
 
toString() - Method in class org.onosproject.net.config.basics.BandwidthCapacity
 
toString() - Method in class org.onosproject.net.config.basics.BasicRegionConfig
 
toString() - Method in class org.onosproject.net.config.basics.BasicUiTopoLayoutConfig
 
toString() - Method in class org.onosproject.net.config.Config
 
toString() - Method in class org.onosproject.net.config.inject.DeviceInjectionConfig
 
toString() - Method in class org.onosproject.net.config.NetworkConfigEvent
 
toString() - Method in class org.onosproject.net.ConnectPoint
 
toString() - Method in class org.onosproject.net.DataPlaneEntity
 
toString() - Method in class org.onosproject.net.DefaultAnnotations
 
toString() - Method in class org.onosproject.net.DefaultDevice
 
toString() - Method in class org.onosproject.net.DefaultHost
 
toString() - Method in class org.onosproject.net.DefaultLink
 
toString() - Method in class org.onosproject.net.DefaultPath
 
toString() - Method in class org.onosproject.net.DefaultPort
 
toString() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
toString() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
 
toString() - Method in class org.onosproject.net.device.DefaultPortDescription
 
toString() - Method in class org.onosproject.net.device.DefaultPortStatistics
 
toString() - Method in class org.onosproject.net.device.DeviceEvent
 
toString() - Method in class org.onosproject.net.DeviceId
 
toString() - Method in class org.onosproject.net.domain.DomainIntentOperation
 
toString() - Method in class org.onosproject.net.domain.DomainIntentOperations
 
toString() - Method in class org.onosproject.net.domain.DomainPointToPointIntent
 
toString() - Method in class org.onosproject.net.driver.DefaultDriver
 
toString() - Method in class org.onosproject.net.driver.DefaultDriverData
 
toString() - Method in class org.onosproject.net.driver.DefaultDriverHandler
 
toString() - Method in class org.onosproject.net.driver.DefaultDriverProvider
 
toString() - Method in class org.onosproject.net.driver.DriverEvent
 
toString() - Method in class org.onosproject.net.FilteredConnectPoint
 
toString() - Method in class org.onosproject.net.flow.BatchOperation
 
toString() - Method in class org.onosproject.net.flow.BatchOperationEntry
 
toString() - Method in class org.onosproject.net.flow.CompletedBatchOperation
 
toString() - Method in class org.onosproject.net.flow.criteria.ArpHaCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.ArpOpCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.ArpPaCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.EthCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.EthTypeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.ExtensionCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.ExtensionSelectorType
 
toString() - Method in class org.onosproject.net.flow.criteria.IcmpCodeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IcmpTypeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.Icmpv6CodeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.Icmpv6TypeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPDscpCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPEcnCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPProtocolCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPv6ExthdrFlagsCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPv6FlowLabelCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPv6NDLinkLayerAddressCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.IPv6NDTargetAddressCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.LambdaCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.MetadataCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.MplsBosCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.MplsCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.MplsTcCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.OchSignalCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.OchSignalTypeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.OduSignalIdCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.OduSignalTypeCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.PbbIsidCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.PiCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.PortCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.SctpPortCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.TcpFlagsCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.TcpPortCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.TunnelIdCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.UdpPortCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
 
toString() - Method in class org.onosproject.net.flow.criteria.VlanIdCriterion
 
toString() - Method in class org.onosproject.net.flow.criteria.VlanPcpCriterion
 
toString() - Method in class org.onosproject.net.flow.DefaultFlowEntry
 
toString() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
toString() - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry
 
toString() - Method in class org.onosproject.net.flow.DefaultTrafficSelector
 
toString() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
toString() - Method in class org.onosproject.net.flow.DefaultTypedFlowEntry
 
toString() - Method in class org.onosproject.net.flow.FlowId
 
toString() - Method in class org.onosproject.net.flow.FlowRuleOperation
 
toString() - Method in class org.onosproject.net.flow.FlowRuleOperations
 
toString() - Method in class org.onosproject.net.flow.instructions.ExtensionTreatmentType
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.ExtensionInstructionWrapper
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.GroupInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.MetadataInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.MeterInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.NoActionInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.OutputInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.SetQueueInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.TableTypeTransition
 
toString() - Method in class org.onosproject.net.flow.instructions.Instructions.TruncateInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction.ModOchSignalInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction.ModOduSignalIdInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModEtherInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsBosInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsHeaderInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsLabelInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModMplsTtlInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModTunnelIdInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanHeaderInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanIdInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanPcpInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpEthInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpIPInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModArpOpInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModDscpInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModIPv6FlowLabelInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction.ModTtlInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction.ModTransportPortInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.PiInstruction
 
toString() - Method in class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
 
toString() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
toString() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
toString() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
toString() - Method in class org.onosproject.net.flowobjective.DefaultNextTreatment
 
toString() - Method in class org.onosproject.net.flowobjective.IdNextTreatment
 
toString() - Method in class org.onosproject.net.group.DefaultGroup
 
toString() - Method in class org.onosproject.net.group.DefaultGroupBucket
 
toString() - Method in class org.onosproject.net.group.DefaultGroupDescription
 
toString() - Method in class org.onosproject.net.group.DefaultGroupKey
Returns a hex string representation of the byte array that is used as a group key.
toString() - Method in class org.onosproject.net.group.GroupBuckets
 
toString() - Method in class org.onosproject.net.host.DefaultHostDescription
 
toString() - Method in class org.onosproject.net.host.HostEvent
 
toString() - Method in class org.onosproject.net.host.HostProbingEvent
 
toString() - Method in class org.onosproject.net.host.InterfaceIpAddress
 
toString() - Method in class org.onosproject.net.HostId
 
toString() - Method in class org.onosproject.net.HostLocation
 
toString() - Method in class org.onosproject.net.intent.constraint.AnnotationConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.BandwidthConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.EncapsulationConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.LatencyConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.LinkTypeConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.MarkerConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.MeteredConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.NonDisruptiveConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.ObstacleConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.PartialFailureConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.ProtectedConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.ProtectionConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.TierConstraint
 
toString() - Method in class org.onosproject.net.intent.constraint.WaypointConstraint
 
toString() - Method in class org.onosproject.net.intent.FlowObjectiveIntent
 
toString() - Method in class org.onosproject.net.intent.FlowRuleIntent
 
toString() - Method in class org.onosproject.net.intent.HostToHostIntent
 
toString() - Method in class org.onosproject.net.intent.IntentData
 
toString() - Method in class org.onosproject.net.intent.IntentId
 
toString() - Method in class org.onosproject.net.intent.IntentInstallationContext
 
toString() - Method in class org.onosproject.net.intent.IntentOperation
 
toString() - Method in class org.onosproject.net.intent.LinkCollectionIntent
 
toString() - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent
 
toString() - Method in class org.onosproject.net.intent.OpticalCircuitIntent
 
toString() - Method in class org.onosproject.net.intent.OpticalConnectivityIntent
 
toString() - Method in class org.onosproject.net.intent.OpticalOduIntent
 
toString() - Method in class org.onosproject.net.intent.OpticalPathIntent
 
toString() - Method in class org.onosproject.net.intent.PathIntent
 
toString() - Method in class org.onosproject.net.intent.PointToPointIntent
 
toString() - Method in class org.onosproject.net.intent.ProtectedTransportIntent
 
toString() - Method in class org.onosproject.net.intent.ProtectionEndpointIntent
 
toString() - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent
 
toString() - Method in class org.onosproject.net.intent.TwoWayP2PIntent
 
toString() - Method in class org.onosproject.net.intf.Interface
 
toString() - Method in class org.onosproject.net.intf.InterfaceEvent
 
toString() - Method in class org.onosproject.net.IpElementId
 
toString() - Method in class org.onosproject.net.link.DefaultLinkDescription
 
toString() - Method in class org.onosproject.net.LinkKey
 
toString() - Method in class org.onosproject.net.MarkerResource
 
toString() - Method in class org.onosproject.net.mcast.McastEvent
Deprecated.
 
toString() - Method in class org.onosproject.net.mcast.McastRoute
Deprecated.
 
toString() - Method in class org.onosproject.net.mcast.McastRouteInfo
Deprecated.
 
toString() - Method in class org.onosproject.net.meter.DefaultBand
 
toString() - Method in class org.onosproject.net.meter.DefaultMeter
 
toString() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
toString() - Method in class org.onosproject.net.meter.DefaultMeterRequest
 
toString() - Method in class org.onosproject.net.meter.MeterFeaturesKey
Deprecated.
 
toString() - Method in class org.onosproject.net.meter.MeterId
 
toString() - Method in class org.onosproject.net.meter.MeterKey
 
toString() - Method in class org.onosproject.net.meter.MeterOperation
 
toString() - Method in class org.onosproject.net.meter.MeterTableKey
 
toString() - Method in class org.onosproject.net.NshContextHeader
 
toString() - Method in class org.onosproject.net.NshServiceIndex
 
toString() - Method in class org.onosproject.net.OchSignal
 
toString() - Method in class org.onosproject.net.OduSignalId
 
toString() - Method in class org.onosproject.net.packet.DefaultInboundPacket
 
toString() - Method in class org.onosproject.net.packet.DefaultOutboundPacket
 
toString() - Method in class org.onosproject.net.packet.DefaultPacketRequest
 
toString() - Method in enum org.onosproject.net.packet.PacketPriority
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiBitString
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiBool
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiEnumString
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiErrorString
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiHeader
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderStack
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnionStack
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiStruct
 
toString() - Method in class org.onosproject.net.pi.runtime.data.PiTuple
 
toString() - Method in class org.onosproject.net.pi.runtime.PiAction
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionParam
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionSet
 
toString() - Method in class org.onosproject.net.pi.runtime.PiActionSet.WeightedAction
 
toString() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry
 
toString() - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntryHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiCounterCell
 
toString() - Method in class org.onosproject.net.pi.runtime.PiCounterCellData
 
toString() - Method in class org.onosproject.net.pi.runtime.PiCounterCellHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiCounterCellId
 
toString() - Method in class org.onosproject.net.pi.runtime.PiExactFieldMatch
 
toString() - Method in class org.onosproject.net.pi.runtime.PiGroupKey
 
toString() - Method in class org.onosproject.net.pi.runtime.PiHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiLpmFieldMatch
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMatchKey
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMeterBand
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMeterCellHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry
 
toString() - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntryHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiOptionalFieldMatch
 
toString() - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata
 
toString() - Method in class org.onosproject.net.pi.runtime.PiPacketOperation
 
toString() - Method in class org.onosproject.net.pi.runtime.PiPreReplica
 
toString() - Method in class org.onosproject.net.pi.runtime.PiRangeFieldMatch
 
toString() - Method in class org.onosproject.net.pi.runtime.PiRegisterCell
 
toString() - Method in class org.onosproject.net.pi.runtime.PiRegisterCellId
 
toString() - Method in class org.onosproject.net.pi.runtime.PiTableEntry
 
toString() - Method in class org.onosproject.net.pi.runtime.PiTableEntryHandle
 
toString() - Method in class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
 
toString() - Method in class org.onosproject.net.PipelineTraceableHitChain
 
toString() - Method in class org.onosproject.net.PipelineTraceablePacket
 
toString() - Method in class org.onosproject.net.PortNumber
 
toString() - Method in class org.onosproject.net.provider.ProviderId
 
toString() - Method in class org.onosproject.net.region.DefaultRegion
 
toString() - Method in class org.onosproject.net.resource.ContinuousResource
 
toString() - Method in class org.onosproject.net.resource.ContinuousResourceId
 
toString() - Method in class org.onosproject.net.resource.DiscreteResource
 
toString() - Method in class org.onosproject.net.resource.DiscreteResourceId
 
toString() - Method in class org.onosproject.net.resource.ResourceAllocation
 
toString() - Method in class org.onosproject.net.ResourceGroup
 
toString() - Method in class org.onosproject.net.statistic.DefaultLoad
 
toString() - Method in class org.onosproject.net.topology.DefaultTopologyCluster
 
toString() - Method in class org.onosproject.net.topology.DefaultTopologyEdge
 
toString() - Method in class org.onosproject.net.topology.DefaultTopologyVertex
 
toString() - Method in class org.onosproject.net.TributarySlot
 
toString() - Method in class org.onosproject.net.utils.ForwardingPort
 
toString() - Method in class org.onosproject.routing.NextHop
 
toString() - Method in class org.onosproject.routing.NextHopGroupKey
 
toString() - Method in class org.onosproject.security.Permission
 
toString() - Method in class org.onosproject.store.cluster.messaging.ClusterMessage
 
toString() - Method in class org.onosproject.store.cluster.messaging.Endpoint
 
toString() - Method in class org.onosproject.store.cluster.messaging.MessageSubject
 
toString() - Method in class org.onosproject.store.LogicalTimestamp
 
toString() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
toString() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
toString() - Method in class org.onosproject.store.primitives.MapUpdate
 
toString() - Method in class org.onosproject.store.primitives.NodeUpdate
 
toString() - Method in class org.onosproject.store.service.AtomicValueEvent
 
toString() - Method in class org.onosproject.store.service.DocumentPath
 
toString() - Method in class org.onosproject.store.service.DocumentTreeEvent
 
toString() - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
 
toString() - Method in class org.onosproject.store.service.MapEvent
 
toString() - Method in class org.onosproject.store.service.MultimapEvent
 
toString() - Method in class org.onosproject.store.service.MultiValuedTimestamp
 
toString() - Method in class org.onosproject.store.service.SetEvent
 
toString() - Method in class org.onosproject.store.service.Task
 
toString() - Method in class org.onosproject.store.service.TransactionLog
 
toString() - Method in class org.onosproject.store.service.Version
 
toString() - Method in class org.onosproject.store.service.Versioned
 
toString() - Method in class org.onosproject.store.service.WallClockTimestamp
 
toString() - Method in class org.onosproject.store.service.WorkQueueStats
 
toString() - Method in class org.onosproject.ui.lion.LionBundle.LionItem
 
toString() - Method in class org.onosproject.ui.lion.LionBundle
 
toString() - Method in class org.onosproject.ui.model.topo.UiClusterMember
 
toString() - Method in class org.onosproject.ui.model.topo.UiDevice
 
toString() - Method in class org.onosproject.ui.model.topo.UiHost
 
toString() - Method in class org.onosproject.ui.model.topo.UiLink
 
toString() - Method in class org.onosproject.ui.model.topo.UiLinkId
 
toString() - Method in class org.onosproject.ui.model.topo.UiRegion
 
toString() - Method in class org.onosproject.ui.model.topo.UiSynthLink
 
toString() - Method in class org.onosproject.ui.model.topo.UiTopoLayout
 
toString() - Method in class org.onosproject.ui.model.topo.UiTopology
 
toString() - Method in class org.onosproject.ui.topo.BiLink
 
toString() - Method in enum org.onosproject.ui.topo.Highlights.Amount
 
toString() - Method in class org.onosproject.ui.topo.LayoutLocation
 
toString() - Method in enum org.onosproject.ui.topo.LayoutLocation.Type
 
toString() - Method in enum org.onosproject.ui.topo.LinkHighlight.Flavor
 
toString() - Method in class org.onosproject.ui.topo.Mod
 
toString() - Method in enum org.onosproject.ui.topo.NodeBadge.Status
 
toString() - Method in class org.onosproject.ui.topo.NodeBadge
 
toString() - Method in class org.onosproject.ui.topo.NodeSelection
 
toString() - Method in class org.onosproject.ui.topo.PropertyPanel.Prop
 
toString() - Method in enum org.onosproject.ui.topo.TopoUtils.Magnitude
 
toString() - Method in class org.onosproject.ui.topo.TopoUtils.ValueLabel
 
toString() - Method in class org.onosproject.ui.UiGlyph
 
toString() - Method in class org.onosproject.ui.UiSessionToken
 
toString() - Method in class org.onosproject.ui.UiTopo2Overlay
 
toString() - Method in class org.onosproject.ui.UiTopoMap
 
toString() - Method in class org.onosproject.ui.UiView
 
toString() - Method in class org.onosproject.ui.UiViewHidden
 
toString() - Method in class org.onosproject.upgrade.Upgrade
 
toString() - Method in class org.onosproject.upgrade.UpgradeEvent
 
toStringHelper() - Method in class org.onosproject.net.utils.ForwardingPort
Returns MoreObjects.ToStringHelper with Port attributes excluding annotations.
toStringList() - Static method in enum org.onosproject.net.behaviour.ControlProtocolVersion
Returns a list of control protocol version string values.
toStringNoColon() - Method in class org.onlab.packet.MacAddress
 
toStringUtf8(byte[]) - Static method in class org.onlab.util.Tools
Returns the String representation of UTF-8 encoded byte[].
toStringWithoutName() - Method in class org.onosproject.net.PortNumber
 
total() - Method in class org.onlab.util.Counter
Returns the total number of occurrences counted.
TOTAL_BPS_BODY_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduBasicParameterSet
 
TOTAL_CPU_TIME - org.onosproject.cpman.ControlMetricType
 
TOTAL_DSAKPS_BODY_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet
 
TOTAL_ICVPS_BODY_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduICVIndicatorParameterSet
 
TOTAL_SUPS_BODY_LENGTH - Static variable in class org.onlab.packet.EAPOLMkpduMACSecUseParameterSet
 
totalCompleted() - Method in class org.onosproject.store.service.WorkQueueStats
Returns the total completed tasks.
totalInProgress() - Method in class org.onosproject.store.service.WorkQueueStats
Returns the total in progress tasks.
totalLength - Variable in class org.onlab.packet.IPv4
 
totalLoad() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Returns total load of connect point.
totalMemory() - Method in interface org.onosproject.cpman.SystemInfo
Returns the total amount of memory in Mega Bytes.
totalMemory(int) - Method in interface org.onosproject.cpman.SystemInfo.Builder
Sets total amount of memory.
totalNanos() - Method in interface org.onosproject.net.packet.PacketProcessorEntry
Returns the total time, in nanoseconds, spent processing packets.
totalPending() - Method in class org.onosproject.store.service.WorkQueueStats
Returns the total pending tasks.
toUninstall() - Method in class org.onosproject.net.intent.IntentInstallationContext
Retrieves the Intent data which to be uninstalled.
toUninstall() - Method in class org.onosproject.net.intent.IntentOperationContext
Retrieves high level Intent data to uninstall.
toWeight(double) - Static method in class org.onlab.graph.ScalarWeight
Creates a new scalar weight with the given double value.
tpid() - Method in class org.onosproject.net.DefaultHost
 
tpid() - Method in class org.onosproject.net.host.DefaultHostDescription
 
tpid() - Method in interface org.onosproject.net.host.HostDescription
Returns the TPID of the outermost VLAN associated with this host.
tpid() - Method in interface org.onosproject.net.Host
Returns the TPID of the outermost VLAN associated with this host.
tpPort(int) - Static method in class org.onlab.packet.TpPort
Converts an integer into a TpPort.
TpPort - Class in org.onlab.packet
Representation of a transport layer port.
TpPort(int) - Constructor for class org.onlab.packet.TpPort
Constructs a new TpPort.
trace(String) - Method in class org.onlab.junit.LoggerAdapter
 
trace(String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
trace(String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
trace(String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
trace(String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
trace(Marker, String) - Method in class org.onlab.junit.LoggerAdapter
 
trace(Marker, String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
trace(Marker, String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
trace(Marker, String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
trace(Marker, String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
TRACE - org.onlab.util.Tools.LogLevel
 
trackIntent(IntentData) - Method in interface org.onosproject.net.intent.ObjectiveTrackerService
Submits the specified intent data to be tracked.
trafficClass - Variable in class org.onlab.packet.IPv6
 
trafficPeriod - Static variable in class org.onosproject.ui.topo.AbstractTopoMonitor
Number of milliseconds between invocations of sending traffic data.
trafficSelector() - Method in class org.onosproject.net.FilteredConnectPoint
Returns the traffic selector for this connect point.
TrafficSelector - Interface in org.onosproject.net.flow
Abstraction of a slice of network traffic.
TrafficSelector.Builder - Interface in org.onosproject.net.flow
Builder of traffic selector entities.
TrafficTreatment - Interface in org.onosproject.net.flow
Abstraction of network traffic treatment.
TrafficTreatment.Builder - Interface in org.onosproject.net.flow
Builder of traffic treatment entities.
TRANSACTION_CONTEXT - org.onosproject.store.service.DistributedPrimitive.Type
Transaction Context.
TRANSACTION_END - org.onosproject.store.service.DocumentTreeEvent.Type
Signifies end of Transaction events.
TRANSACTION_START - org.onosproject.store.service.DocumentTreeEvent.Type
Signifies beginning of Transaction events.
Transactional<T> - Interface in org.onosproject.store.service
Interface for transactional primitives.
TransactionalMap<K,​V> - Interface in org.onosproject.store.service
Transactional Map data structure.
TransactionalSet<E> - Interface in org.onosproject.store.service
Transactional Set data structure.
TransactionContext - Interface in org.onosproject.store.service
Provides a context for transactional operations.
transactionContextBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new transaction context builder.
transactionContextBuilder() - Method in interface org.onosproject.store.service.StorageService
Creates a new transaction context builder.
TransactionContextBuilder - Class in org.onosproject.store.service
Abstract base class for a transaction context builder.
TransactionContextBuilder() - Constructor for class org.onosproject.store.service.TransactionContextBuilder
 
TransactionContextOptions<O extends TransactionContextOptions<O>> - Class in org.onosproject.store.service
Abstract base class for a transaction context builder.
TransactionContextOptions() - Constructor for class org.onosproject.store.service.TransactionContextOptions
 
TransactionException - Exception in org.onosproject.store.service
Top level exception for Transaction failures.
TransactionException() - Constructor for exception org.onosproject.store.service.TransactionException
 
TransactionException(Throwable) - Constructor for exception org.onosproject.store.service.TransactionException
 
TransactionException.ConcurrentModification - Exception in org.onosproject.store.service
Transaction failure due to a conflicting transaction in progress.
TransactionException.Interrupted - Exception in org.onosproject.store.service
Transaction interrupted.
TransactionException.OptimisticConcurrencyFailure - Exception in org.onosproject.store.service
Transaction failure due to optimistic concurrency violation.
TransactionException.Timeout - Exception in org.onosproject.store.service
Transaction timeout.
transactionId - Variable in class org.onlab.packet.DHCP
 
transactionId() - Method in interface org.onosproject.store.service.TransactionContext
Returns the transaction identifier.
transactionId() - Method in class org.onosproject.store.service.TransactionLog
Returns the transaction identifier.
TransactionId - Class in org.onosproject.store.primitives
Transaction identifier.
TransactionLog<T> - Class in org.onosproject.store.service
Collection of transaction updates to be applied atomically.
TransactionLog(TransactionId, long, List<T>) - Constructor for class org.onosproject.store.service.TransactionLog
 
TransactionsCommand - Class in org.onosproject.cli.net
CLI to view in-progress database transactions in the system.
TransactionsCommand() - Constructor for class org.onosproject.cli.net.TransactionsCommand
 
transferLeadership(String, NodeId) - Method in interface org.onosproject.cluster.LeadershipAdminService
Attempts to assign leadership for a topic to a specified node.
TRANSIT - org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable.IntFunctionality
Transit functionality.
transition(Integer) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
transition(Integer) - Static method in class org.onosproject.net.flow.instructions.Instructions
Sends the packet to the table id.
transition(Integer) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Sets the next table id to transition to.
translate(T, PiPipeconf) - Method in interface org.onosproject.net.pi.service.PiTranslator
Translate the given PD entity (original) and returns a PI entity that is equivalent to he PD one for the given pipeconf.
translateAlarms(List<T>) - Method in interface org.onosproject.alarm.DeviceAlarmConfig
Returns the list of translated alarms from device-specific representation to ONOS alarms.
translated() - Method in class org.onosproject.net.pi.service.PiTranslatedEntity
Returns the translated PI entity.
translateToAlarm(DeviceId, InputStream) - Method in interface org.onosproject.alarm.AlarmTranslator
Translates message from device into an alarm with appropriate information.
TransportEndpointDescription - Class in org.onosproject.net.behaviour.protection
Configuration for a underlying path endpoint, forming protected path.
TransportEndpointDescription(FilteredConnectPoint, boolean) - Constructor for class org.onosproject.net.behaviour.protection.TransportEndpointDescription
 
TransportEndpointDescription.Builder - Class in org.onosproject.net.behaviour.protection
 
TransportEndpointId - Class in org.onosproject.net.behaviour.protection
Identifier for a transport entity endpoint.
TransportEndpointId() - Constructor for class org.onosproject.net.behaviour.protection.TransportEndpointId
 
TransportEndpointId(String) - Constructor for class org.onosproject.net.behaviour.protection.TransportEndpointId
 
TransportEndpointState - Class in org.onosproject.net.behaviour.protection
State of a underlying path endpoint, forming protected path.
TransportEndpointState(TransportEndpointDescription, TransportEndpointId, boolean, Map<String, String>) - Constructor for class org.onosproject.net.behaviour.protection.TransportEndpointState
 
TransportEndpointState.Builder - Class in org.onosproject.net.behaviour.protection
 
treatment - Variable in class org.onosproject.net.domain.DomainIntent.Builder
 
treatment - Variable in class org.onosproject.net.intent.ConnectivityIntent.Builder
 
treatment() - Method in class org.onosproject.net.domain.DomainIntent
Returns the action applied to the traffic at the egress.
treatment() - Method in class org.onosproject.net.flow.DefaultFlowRule
 
treatment() - Method in interface org.onosproject.net.flow.FlowRule
Returns the traffic treatment that applies to selected traffic.
treatment() - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective
 
treatment() - Method in class org.onosproject.net.flowobjective.DefaultNextTreatment
Returns traffic treatment.
treatment() - Method in interface org.onosproject.net.flowobjective.ForwardingObjective
A traffic treatment for this forwarding objective.
treatment() - Method in class org.onosproject.net.group.DefaultGroupBucket
Returns list of Traffic instructions that are part of the bucket.
treatment() - Method in interface org.onosproject.net.group.GroupBucket
Returns list of Traffic instructions that are part of the bucket.
treatment() - Method in class org.onosproject.net.intent.ConnectivityIntent
Returns the action applied to the traffic.
treatment() - Method in class org.onosproject.net.packet.DefaultOutboundPacket
 
treatment() - Method in interface org.onosproject.net.packet.OutboundPacket
Returns how the outbound packet should be treated.
treatment(TrafficTreatment) - Method in class org.onosproject.net.domain.DomainIntent.Builder
Sets the traffic treatment for the intent that will be built.
treatment(TrafficTreatment) - Method in class org.onosproject.net.domain.DomainPointToPointIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.ConnectivityIntent.Builder
Sets the traffic treatment for the intent that will be built.
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.LinkCollectionIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.MultiPointToSinglePointIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.PathIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.PointToPointIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.SinglePointToMultiPointIntent.Builder
 
treatment(TrafficTreatment) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
 
TREATMENT - org.onosproject.net.flowobjective.NextTreatment.Type
The next action is specified by a TrafficTreatment.
treatmentBuilder() - Method in class org.onosproject.net.packet.DefaultPacketContext
 
treatmentBuilder() - Method in interface org.onosproject.net.packet.PacketContext
Returns a builder for constructing traffic treatment.
TREE_EDGE - org.onlab.graph.DepthFirstSearch.EdgeType
 
TRIANGLE_DOWN - Static variable in class org.onosproject.ui.GlyphConstants
 
TRIANGLE_UP - Static variable in class org.onosproject.ui.GlyphConstants
 
TRIBUTARY_SLOT_BITMAP_SIZE - Static variable in class org.onosproject.net.OduSignalId
 
tributaryPortNumber() - Method in class org.onosproject.net.OduSignalId
Returns tributary port number.
TributarySlot - Class in org.onosproject.net
Implementation of ODU Tributary Slot simply designated by an index number of slot.
TributarySlot(long) - Constructor for class org.onosproject.net.TributarySlot
Creates an instance representing the TributarySlot specified by the given index number.
tributarySlotBitmap() - Method in class org.onosproject.net.OduSignalId
Returns tributary slot bitmap.
tributarySlotLength() - Method in class org.onosproject.net.OduSignalId
Returns tributary slot length.
TributarySlotQuery - Interface in org.onosproject.net.behaviour
Behaviour to retrieve available tributary slot resources.
tributarySlots() - Method in enum org.onosproject.net.OduSignalType
Returns the number of tributary slots of the OduSignalType.
TriConsumer<U,​V,​W> - Interface in org.onlab.util
A consumer that accepts three arguments.
triggerCompile(Iterable<Key>, boolean) - Method in interface org.onosproject.net.intent.TopologyChangeDelegate
Notifies that topology has changed in such a way that the specified intents should be recompiled.
triggerDisconnect(DeviceId) - Method in interface org.onosproject.net.device.DeviceProvider
Administratively triggers 'disconnection' from the device.
triggerProbe(DeviceId) - Method in interface org.onosproject.alarm.AlarmProvider
Triggers an asynchronous discovery of the alarms on the specified device, intended to refresh internal alarm model for the device.
triggerProbe(DeviceId) - Method in interface org.onosproject.net.device.DeviceProvider
Triggers an asynchronous probe of the specified device, intended to determine whether the device is present or not.
triggerProbe(DeviceId) - Method in interface org.onosproject.net.pi.service.PiPipeconfWatchdogService
Asynchronously triggers a probe task that checks the device pipeline status and, if required, configures it with the pipeconf associated to this device (via PiPipeconfService.bindToDevice(PiPipeconfId, DeviceId)).
triggerProbe(Host) - Method in interface org.onosproject.net.host.HostProvider
Triggers an asynchronous probe of the specified host, intended to determine whether the host is present or not.
triggerRecompute() - Method in interface org.onosproject.net.topology.TopologyProvider
Triggers topology recomputation.
truncate(int) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
truncate(int) - Static method in class org.onosproject.net.flow.instructions.Instructions
Creates a truncate instruction.
truncate(int) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Adds a truncate instruction.
TRUNCATE - org.onosproject.net.flow.instructions.Instruction.Type
Signifies that the packet should be truncated.
TruncateInstruction(int) - Constructor for class org.onosproject.net.flow.instructions.Instructions.TruncateInstruction
 
TRUNK - org.onosproject.net.device.DeviceInterfaceDescription.Mode
Trunk mode for a set of VLANs for interface.
tryAcquireShared(int) - Method in class org.onlab.util.BlockingBoolean
 
tryLock() - Method in class org.onosproject.store.primitives.DefaultDistributedLock
 
tryLock() - Method in interface org.onosproject.store.service.AsyncDistributedLock
Attempts to acquire the lock.
tryLock() - Method in interface org.onosproject.store.service.DistributedLock
Attempts to acquire the lock.
tryLock(Duration) - Method in class org.onosproject.store.primitives.DefaultDistributedLock
 
tryLock(Duration) - Method in interface org.onosproject.store.service.AsyncDistributedLock
Attempts to acquire the lock for a specified amount of time.
tryLock(Duration) - Method in interface org.onosproject.store.service.DistributedLock
Attempts to acquire the lock for a specified amount of time.
tryReleaseShared(int) - Method in class org.onlab.util.BlockingBoolean
 
ttl - Variable in class org.onlab.packet.IPv4
 
ttl - Variable in class org.onlab.packet.LLDP
 
ttl - Variable in class org.onlab.packet.MPLS
 
TTL_IN - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
Copy TTL in.
TTL_OUT - org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
Copy TTL out.
TTL_TLV_SIZE - Static variable in class org.onlab.packet.LLDP
 
TTL_TLV_TYPE - Static variable in class org.onlab.packet.LLDP
 
tunnel() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
A description of the tunnel that this FAR will encapsulate packets with, if it is a downlink FAR.
TUNNEL - org.onosproject.net.Link.Type
Signifies that this link represents a logical link backed by some form of a tunnel, e.g., GRE, MPLS, ODUk, OCH.
TUNNEL_EVENT - org.onosproject.security.AppPermission.Type
 
TUNNEL_ID - org.onosproject.net.flow.criteria.Criterion.Type
Logical Port Metadata.
TUNNEL_ID - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
Tunnel id modification.
TUNNEL_READ - org.onosproject.security.AppPermission.Type
 
TUNNEL_WRITE - org.onosproject.security.AppPermission.Type
 
TunnelDescription - Interface in org.onosproject.net.behaviour
Describes a tunnel interface.
TunnelDescription.Builder - Interface in org.onosproject.net.behaviour
Builder of tunnel interface description entities.
TunnelDescription.Type - Enum in org.onosproject.net.behaviour
Tunnel technology type.
tunnelDest() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Get the destination IP of the GTP tunnel that this PDR matches on.
tunnelDst() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Get the destination IP of the GTP tunnel that this FAR will encapsulate packets with.
TunnelEndPoint<T> - Class in org.onosproject.net.behaviour
Represents for source end point or destination end point of a tunnel.
TunnelEndPoint(T) - Constructor for class org.onosproject.net.behaviour.TunnelEndPoint
Default constructor.
TunnelEndPoints - Class in org.onosproject.net.behaviour
Static utility methods pertaining to TunnelEndPoint instances.
tunnelId() - Method in class org.onosproject.net.flow.criteria.TunnelIdCriterion
Gets the Tunnel ID to match.
tunnelId() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModTunnelIdInstruction
 
TunnelIdCriterion - Class in org.onosproject.net.flow.criteria
Implementation of Tunnel ID criterion.
TunnelKey<T> - Class in org.onosproject.net.behaviour
Represent for a tunnel key.
TunnelKey(T) - Constructor for class org.onosproject.net.behaviour.TunnelKey
Default constructor.
TunnelKeys - Class in org.onosproject.net.behaviour
Static utility methods pertaining to TunnelKey instances.
TUNNELS - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
tunnelSrc() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Get the source IP of the GTP tunnel that this FAR will encapsulate packets with.
tunnelSrcPort() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Get the source UDP port of the GTP tunnel that this FAR will encapsulate packets with.
tuple() - Method in class org.onosproject.net.pi.runtime.data.PiTuple
Return protocol-independent tuple instance.
TUPLE - org.onosproject.net.pi.model.PiData.Type
Tuple.
tweakBytes(Random, byte[], int) - Static method in class org.onlab.junit.TestTools
Tweaks the given number of bytes in a byte array.
tweakBytes(Random, byte[], int, int, int) - Static method in class org.onlab.junit.TestTools
Tweaks the given number of bytes in the specified range of a byte array.
two() - Method in class org.onosproject.net.intent.HostToHostIntent
Returns identifier of the second host.
two() - Method in class org.onosproject.net.intent.ProtectedTransportIntent
Returns the transport endpoint device two.
two() - Method in class org.onosproject.net.intent.TwoWayP2PIntent
Returns identifier of the second host.
two() - Method in class org.onosproject.ui.topo.BiLink
Returns the second link in this bi-link.
two(ConnectPoint) - Method in class org.onosproject.net.intent.TwoWayP2PIntent.Builder
Sets the second connection point of the two way intent that will be built.
two(DeviceId) - Method in class org.onosproject.net.intent.ProtectedTransportIntent.Builder
Sets the transport endpoint device two.
two(HostId) - Method in class org.onosproject.net.intent.HostToHostIntent.Builder
Sets the second host of the intent that will be built.
TwoWayP2PIntent - Class in org.onosproject.net.intent
Abstraction of bidirectional connectivity between two points in the network.
TwoWayP2PIntent.Builder - Class in org.onosproject.net.intent
Builder of a point to point intent.
type - Variable in class org.onlab.packet.bmp.Bmp
 
type - Variable in class org.onlab.packet.bmp.BmpPeer
 
type - Variable in class org.onlab.packet.EAP
 
type - Variable in class org.onlab.packet.ipv6.BaseOptions
 
type - Variable in class org.onlab.packet.LLDPTLV
 
type - Variable in class org.onlab.packet.PIM
 
type - Variable in class org.onlab.packet.PPPoED
 
type - Variable in class org.onlab.packet.PPPoEDTag
 
type - Variable in class org.onlab.packet.RADIUSAttribute
 
type - Variable in class org.onlab.packet.RIPV2AuthEntry
 
type - Variable in class org.onosproject.security.AppPermission
 
type() - Method in class org.onlab.packet.ndp.NeighborDiscoveryOptions.Option
Gets the option type.
type() - Method in class org.onosproject.cfg.ConfigProperty
Returns the property type.
type() - Method in interface org.onosproject.cpman.ControlMessage
Returns the control message type.
type() - Method in class org.onosproject.cpman.DefaultControlMessage
 
type() - Method in class org.onosproject.event.AbstractEvent
 
type() - Method in interface org.onosproject.event.Event
Returns the type of the event.
type() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the bandwidth profile type depending on the profile parameters.
type() - Method in interface org.onosproject.net.behaviour.BngProgrammable.Attachment
Returns the type of attachment.
type() - Method in class org.onosproject.net.behaviour.ControllerInfo
Exposes the type of the controller connection.
type() - Method in class org.onosproject.net.behaviour.DefaultQosDescription
 
type() - Method in class org.onosproject.net.behaviour.DefaultQueueDescription
 
type() - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription
 
type() - Method in interface org.onosproject.net.behaviour.QosDescription
Returns qos type.
type() - Method in interface org.onosproject.net.behaviour.QueueDescription
Returns type.
type() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket
 
type() - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket
Token bucket type.
type() - Method in interface org.onosproject.net.behaviour.TunnelDescription
Returns the tunnel type.
type() - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Returns the device type.
type() - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Returns the link type.
type() - Method in class org.onosproject.net.config.basics.BasicRegionConfig
Returns the region type.
type() - Method in class org.onosproject.net.DefaultDevice
 
type() - Method in class org.onosproject.net.DefaultLink
 
type() - Method in class org.onosproject.net.DefaultPort
 
type() - Method in class org.onosproject.net.device.DefaultDeviceDescription
 
type() - Method in class org.onosproject.net.device.DefaultPortDescription
 
type() - Method in interface org.onosproject.net.device.DeviceDescription
Returns the type of the infrastructure device.
type() - Method in interface org.onosproject.net.device.PortDescription
Returns the port type.
type() - Method in interface org.onosproject.net.Device
Returns the type of the infrastructure device.
type() - Method in class org.onosproject.net.domain.DomainIntentOperation
Returns the type of operation.
type() - Method in class org.onosproject.net.flow.criteria.ArpHaCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.ArpOpCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.ArpPaCriterion
 
type() - Method in interface org.onosproject.net.flow.criteria.Criterion
Returns the type of criterion.
type() - Method in class org.onosproject.net.flow.criteria.EthCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.EthTypeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.ExtensionCriterion
 
type() - Method in interface org.onosproject.net.flow.criteria.ExtensionSelector
Gets the type of the extension selector.
type() - Method in enum org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
Gets the extension type object for this named type code.
type() - Method in class org.onosproject.net.flow.criteria.IcmpCodeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IcmpTypeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.Icmpv6CodeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.Icmpv6TypeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPDscpCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPEcnCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPProtocolCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPv6ExthdrFlagsCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPv6FlowLabelCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPv6NDLinkLayerAddressCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.IPv6NDTargetAddressCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.LambdaCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.MetadataCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.MplsBosCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.MplsCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.MplsTcCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.OchSignalCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.OchSignalTypeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.OduSignalIdCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.OduSignalTypeCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.PbbIsidCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.PiCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.PortCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.SctpPortCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.TcpFlagsCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.TcpPortCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.TunnelIdCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.UdpPortCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
 
type() - Method in class org.onosproject.net.flow.criteria.VlanIdCriterion
 
type() - Method in class org.onosproject.net.flow.criteria.VlanPcpCriterion
 
type() - Method in class org.onosproject.net.flow.FlowRuleOperation
Returns the type of operation.
type() - Method in class org.onosproject.net.flow.IndexTableId
 
type() - Method in interface org.onosproject.net.flow.instructions.ExtensionTreatment
Gets the type of the treatment extension.
type() - Method in enum org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
Gets the extension type object for this named type code.
type() - Method in class org.onosproject.net.flow.instructions.ExtensionTreatmentType
Returns extension treatment type.
type() - Method in interface org.onosproject.net.flow.instructions.Instruction
Returns the type of instruction.
type() - Method in class org.onosproject.net.flow.instructions.Instructions.ExtensionInstructionWrapper
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.GroupInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.MetadataInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.MeterInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.NoActionInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.OutputInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.SetQueueInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.StatTriggerInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.TableTypeTransition
 
type() - Method in class org.onosproject.net.flow.instructions.Instructions.TruncateInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.L0ModificationInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.L1ModificationInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.L3ModificationInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.L4ModificationInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.PiInstruction
 
type() - Method in class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
 
type() - Method in interface org.onosproject.net.flow.TableId
Gets type of this table ID.
type() - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective
 
type() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective
 
type() - Method in class org.onosproject.net.flowobjective.DefaultNextTreatment
 
type() - Method in interface org.onosproject.net.flowobjective.FilteringObjective
Obtain this filtering type.
type() - Method in class org.onosproject.net.flowobjective.IdNextTreatment
 
type() - Method in interface org.onosproject.net.flowobjective.NextObjective
The type of operation that will be applied to the traffic using the collection of treatments.
type() - Method in interface org.onosproject.net.flowobjective.NextTreatment
Type of this next action.
type() - Method in class org.onosproject.net.group.DefaultGroupBucket
 
type() - Method in class org.onosproject.net.group.DefaultGroupDescription
Returns type of a group object.
type() - Method in interface org.onosproject.net.group.GroupBucket
Returns group type of the bucket.
type() - Method in interface org.onosproject.net.group.GroupDescription
Returns type of a group object.
type() - Method in class org.onosproject.net.intent.FlowRuleIntent
 
type() - Method in class org.onosproject.net.intent.IntentOperation
Returns the type of the operation.
type() - Method in class org.onosproject.net.intent.PathIntent
 
type() - Method in class org.onosproject.net.key.DeviceKey
Returns the type of the device key.
type() - Method in class org.onosproject.net.link.DefaultLinkDescription
 
type() - Method in interface org.onosproject.net.link.LinkDescription
Returns the link type.
type() - Method in interface org.onosproject.net.Link
Returns the link type.
type() - Method in class org.onosproject.net.mcast.McastRoute
Deprecated.
Obtains how this route was created.
type() - Method in interface org.onosproject.net.meter.Band
Signals the type of band to create.
type() - Method in class org.onosproject.net.meter.DefaultBand
 
type() - Method in interface org.onosproject.net.meter.MeterCellId
Return the type of this meter cell identifier.
type() - Method in class org.onosproject.net.meter.MeterId
 
type() - Method in class org.onosproject.net.meter.MeterOperation
Returns the type of operation.
type() - Method in class org.onosproject.net.meter.MeterStoreResult
 
type() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the message type of the packet.
type() - Method in interface org.onosproject.net.pi.model.PiData
Returns the type of this protocol-independent data.
type() - Method in interface org.onosproject.net.pi.model.PiPacketOperationModel
Returns the type of this packet operation.
type() - Method in class org.onosproject.net.pi.model.PiTableId
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiBitString
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiBool
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiEnumString
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiErrorString
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiHeader
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderStack
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnion
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiHeaderUnionStack
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiStruct
 
type() - Method in class org.onosproject.net.pi.runtime.data.PiTuple
 
type() - Method in class org.onosproject.net.pi.runtime.PiAction
 
type() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroupId
 
type() - Method in class org.onosproject.net.pi.runtime.PiActionProfileMemberId
 
type() - Method in class org.onosproject.net.pi.runtime.PiActionSet
 
type() - Method in class org.onosproject.net.pi.runtime.PiExactFieldMatch
 
type() - Method in class org.onosproject.net.pi.runtime.PiFieldMatch
Returns the type of match to be performed.
type() - Method in class org.onosproject.net.pi.runtime.PiLpmFieldMatch
 
type() - Method in class org.onosproject.net.pi.runtime.PiMeterBand
Returns the type of this band.
type() - Method in class org.onosproject.net.pi.runtime.PiMeterCellId
 
type() - Method in class org.onosproject.net.pi.runtime.PiOptionalFieldMatch
 
type() - Method in class org.onosproject.net.pi.runtime.PiPacketOperation
Return the type of this packet.
type() - Method in class org.onosproject.net.pi.runtime.PiRangeFieldMatch
 
type() - Method in interface org.onosproject.net.pi.runtime.PiTableAction
Type of this action.
type() - Method in class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
 
type() - Method in interface org.onosproject.net.Port
Returns the port type.
type() - Method in class org.onosproject.net.region.DefaultRegion
 
type() - Method in interface org.onosproject.net.region.Region
Returns the region type.
type() - Method in interface org.onosproject.net.utils.ForwardingDevice
 
type() - Method in class org.onosproject.net.utils.ForwardingPort
 
type() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns the primitive type.
type() - Method in class org.onosproject.store.primitives.MapUpdate
Returns the type of update operation.
type() - Method in class org.onosproject.store.primitives.NodeUpdate
Returns the type of update operation.
type() - Method in class org.onosproject.store.service.AtomicValueEvent
Returns the type of the event.
type() - Method in class org.onosproject.store.service.DocumentTreeEvent
Returns the change type.
type() - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
Returns the type of the event.
type() - Method in class org.onosproject.store.service.MapEvent
Returns the type of the event.
type() - Method in class org.onosproject.store.service.MultimapEvent
Returns the type of the event.
type() - Method in class org.onosproject.store.service.SetEvent
Returns the type of the event.
type() - Method in class org.onosproject.ui.model.topo.UiDevice
Returns a string representation of the type of the backing device.
type() - Method in class org.onosproject.ui.model.topo.UiLink
Returns the implementing class name as the type of link.
type() - Method in class org.onosproject.ui.model.topo.UiLinkId
Returns the type of link this identifier represents.
type() - Method in class org.onosproject.ui.model.topo.UiRegion
Returns the region's type.
type() - Method in class org.onosproject.ui.topo.AbstractHighlight
Returns the element type.
type(EnumSet<QueueDescription.Type>) - Method in class org.onosproject.net.behaviour.DefaultQueueDescription.Builder
 
type(EnumSet<QueueDescription.Type>) - Method in interface org.onosproject.net.behaviour.QueueDescription.Builder
Returns queue description builder with given type.
type(QosDescription.Type) - Method in class org.onosproject.net.behaviour.DefaultQosDescription.Builder
 
type(QosDescription.Type) - Method in interface org.onosproject.net.behaviour.QosDescription.Builder
Returns qos description builder with a given type.
type(TunnelDescription.Type) - Method in class org.onosproject.net.behaviour.DefaultTunnelDescription.Builder
 
type(TunnelDescription.Type) - Method in interface org.onosproject.net.behaviour.TunnelDescription.Builder
Returns tunnel interface description builder with a given tunnel type.
type(Device.Type) - Method in class org.onosproject.net.config.basics.BasicDeviceConfig
Sets the device type.
type(Link.Type) - Method in class org.onosproject.net.config.basics.BasicLinkConfig
Sets the link type.
type(Link.Type) - Method in class org.onosproject.net.DefaultLink.Builder
Sets the link type to be used by the builder.
type(Port.Type) - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
Sets port type.
type(Region.Type) - Method in class org.onosproject.net.config.basics.BasicRegionConfig
Sets the region type.
TYPE - Static variable in class org.onosproject.net.AnnotationKeys
Deprecated.
since Cardinal
TYPE - Static variable in class org.onosproject.net.config.basics.BasicLinkConfig
 
TYPE_ACTOR - Static variable in class org.onlab.packet.lacp.Lacp
 
TYPE_ARP - Static variable in class org.onlab.packet.Ethernet
 
TYPE_ASSERT - Static variable in class org.onlab.packet.PIM
 
TYPE_BOOTSTRAP - Static variable in class org.onlab.packet.PIM
 
TYPE_BSN - Static variable in class org.onlab.packet.Ethernet
 
TYPE_CANDIDATE_RP_ADV - Static variable in class org.onlab.packet.PIM
 
TYPE_COLLECTOR - Static variable in class org.onlab.packet.lacp.Lacp
 
TYPE_DESERIALIZER_MAP - Static variable in class org.onlab.packet.ICMP6
 
TYPE_ECHO_REPLY - Static variable in class org.onlab.packet.ICMP
 
TYPE_ECHO_REQUEST - Static variable in class org.onlab.packet.ICMP
 
TYPE_GRAFT - Static variable in class org.onlab.packet.PIM
 
TYPE_GRAFT_ACK - Static variable in class org.onlab.packet.PIM
 
TYPE_HELLO - Static variable in class org.onlab.packet.PIM
 
TYPE_IGMPV1_MEMBERSHIP_REPORT - Static variable in class org.onlab.packet.IGMP
 
TYPE_IGMPV2_LEAVE_GROUP - Static variable in class org.onlab.packet.IGMP
 
TYPE_IGMPV2_MEMBERSHIP_REPORT - Static variable in class org.onlab.packet.IGMP
 
TYPE_IGMPV3_MEMBERSHIP_QUERY - Static variable in class org.onlab.packet.IGMP
 
TYPE_IGMPV3_MEMBERSHIP_REPORT - Static variable in class org.onlab.packet.IGMP
 
TYPE_IPV4 - Static variable in class org.onlab.packet.Ethernet
 
TYPE_IPV6 - Static variable in class org.onlab.packet.Ethernet
 
TYPE_JOIN_PRUNE_REQUEST - Static variable in class org.onlab.packet.PIM
 
TYPE_LLDP - Static variable in class org.onlab.packet.Ethernet
 
TYPE_MTU - Static variable in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
TYPE_PARTNER - Static variable in class org.onlab.packet.lacp.Lacp
 
TYPE_PPPOED - Static variable in class org.onlab.packet.Ethernet
 
TYPE_PREFIX_INFORMATION - Static variable in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
TYPE_QINQ - Static variable in class org.onlab.packet.Ethernet
 
TYPE_RARP - Static variable in class org.onlab.packet.Ethernet
 
TYPE_REDIRECTED_HEADER - Static variable in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
TYPE_REGISTER - Static variable in class org.onlab.packet.PIM
 
TYPE_REGISTER_STOP - Static variable in class org.onlab.packet.PIM
 
TYPE_SOURCE_LL_ADDRESS - Static variable in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
TYPE_TARGET_LL_ADDRESS - Static variable in class org.onlab.packet.ndp.NeighborDiscoveryOptions
 
TYPE_TERMINATOR - Static variable in class org.onlab.packet.lacp.Lacp
 
TYPE_VLAN - Static variable in class org.onlab.packet.Ethernet
 
TypedFlowEntryWithLoad - Class in org.onosproject.net.statistic
Load of flow entry of flow live type.
TypedFlowEntryWithLoad(ConnectPoint, FlowEntry) - Constructor for class org.onosproject.net.statistic.TypedFlowEntryWithLoad
Creates a new typed flow entry with load.
TypedFlowEntryWithLoad(ConnectPoint, TypedStoredFlowEntry) - Constructor for class org.onosproject.net.statistic.TypedFlowEntryWithLoad
Creates a new typed flow entry with load.
TypedFlowEntryWithLoad(ConnectPoint, TypedStoredFlowEntry, Load) - Constructor for class org.onosproject.net.statistic.TypedFlowEntryWithLoad
Creates a new typed flow entry with load.
typedPollInterval(TypedStoredFlowEntry) - Static method in class org.onosproject.net.statistic.TypedFlowEntryWithLoad
Returns current typed flow entry's polling interval.
typedStoredFlowEntry() - Method in class org.onosproject.net.statistic.TypedFlowEntryWithLoad
 
TypedStoredFlowEntry - Interface in org.onosproject.net.flow
Represents a flow live type for a given flow entry.
TypedStoredFlowEntry.FlowLiveType - Enum in org.onosproject.net.flow
 
types() - Method in class org.onosproject.net.intent.constraint.LinkTypeConstraint
Returns the set of link types.

U

U_BAND_MAX - Static variable in class org.onlab.util.Spectrum
 
U_BAND_MIN - Static variable in class org.onlab.util.Spectrum
 
UDP - Class in org.onlab.packet
Representation of a UDP packet.
UDP - org.onosproject.cli.net.IpProtocol
UDP.
UDP() - Constructor for class org.onlab.packet.UDP
 
UDP_DST - org.onosproject.net.flow.criteria.Criterion.Type
UDP destination port.
UDP_DST - org.onosproject.net.flow.instructions.L4ModificationInstruction.L4SubType
UDP dst modification.
UDP_DST_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
UDP destination port with masking.
UDP_SRC - org.onosproject.net.flow.criteria.Criterion.Type
UDP source port.
UDP_SRC - org.onosproject.net.flow.instructions.L4ModificationInstruction.L4SubType
UDP src modification.
UDP_SRC_MASKED - org.onosproject.net.flow.criteria.Criterion.Type
UDP source port with masking.
udpPort() - Method in class org.onosproject.net.flow.criteria.UdpPortCriterion
Gets the UDP port to match.
UdpPortCriterion - Class in org.onosproject.net.flow.criteria
Implementation of UDP port criterion (16 bits unsigned integer).
ueAddress() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Get the UE IP address that this PDR matches on.
UI_ATTACHED - Static variable in class org.onosproject.ui.GlyphConstants
 
UI_READ - org.onosproject.security.AppPermission.Type
 
UI_TYPE - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for UI type (the glyph ID for rendering).
UI_TYPE - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Key for UI type (glyph identifier).
UI_WRITE - org.onosproject.security.AppPermission.Type
 
ui2() - Method in class org.onosproject.ui.UiExtension.Builder
Marks this as ui2valid for Ui2.
UiClusterMember - Class in org.onosproject.ui.model.topo
Represents an individual member of the cluster (ONOS instance).
UiClusterMember(UiTopology, ControllerNode) - Constructor for class org.onosproject.ui.model.topo.UiClusterMember
Constructs a UI cluster member, with a reference to the parent topology instance and the specified controller node instance.
UiConnection - Interface in org.onosproject.ui
Abstraction of a user interface session connection.
UiDevice - Class in org.onosproject.ui.model.topo
Represents a device.
UiDevice(UiTopology, Device) - Constructor for class org.onosproject.ui.model.topo.UiDevice
Creates a new UI device.
UiDeviceLink - Class in org.onosproject.ui.model.topo
Represents a link between two devices; that is, an infrastructure link.
UiDeviceLink(UiTopology, UiLinkId) - Constructor for class org.onosproject.ui.model.topo.UiDeviceLink
Creates a device to device UI link.
UiEdgeLink - Class in org.onosproject.ui.model.topo
Designates a link between a device and a host; that is, an edge link.
UiEdgeLink(UiTopology, UiLinkId) - Constructor for class org.onosproject.ui.model.topo.UiEdgeLink
Creates a UI link.
UiElement - Class in org.onosproject.ui.model.topo
Abstract base class of all elements in the UI topology model.
UiElement() - Constructor for class org.onosproject.ui.model.topo.UiElement
 
UiExtension - Class in org.onosproject.ui
Immutable representation of a user interface extension.
UiExtension.Builder - Class in org.onosproject.ui
UI Extension Builder.
UiExtensionService - Interface in org.onosproject.ui
Service for registering user interface extensions.
UiGlyph - Class in org.onosproject.ui
Represents a glyph to be used in the user interface topology view.
UiGlyph(String, String, String) - Constructor for class org.onosproject.ui.UiGlyph
Creates a new glyph.
UiGlyphFactory - Interface in org.onosproject.ui
Abstraction of an entity capable of producing one or more glyphs for the topology view.
UiHost - Class in org.onosproject.ui.model.topo
Represents an end-station host.
UiHost(UiTopology, Host) - Constructor for class org.onosproject.ui.model.topo.UiHost
Creates a new UI host.
UiLink - Class in org.onosproject.ui.model.topo
Represents a link (line between two elements).
UiLink(UiTopology, UiLinkId) - Constructor for class org.onosproject.ui.model.topo.UiLink
Creates a UI link.
uiLinkId() - Method in class org.onosproject.ui.topo.BiLink
Returns the UI link identifier for this bi-link (if set).
uiLinkId(DeviceId, PortNumber, DeviceId, PortNumber) - Static method in class org.onosproject.ui.model.topo.UiLinkId
Generates an identifier for a link between two devices.
uiLinkId(HostId, DeviceId, PortNumber) - Static method in class org.onosproject.ui.model.topo.UiLinkId
Generates an identifier for an edge link.
uiLinkId(Link) - Static method in class org.onosproject.ui.model.topo.UiLinkId
Generates the canonical link identifier for the given link.
uiLinkId(LinkKey) - Static method in class org.onosproject.ui.model.topo.UiLinkId
Creates the canonical link identifier from the given link key.
uiLinkId(RegionId, DeviceId, PortNumber) - Static method in class org.onosproject.ui.model.topo.UiLinkId
Generates the canonical link identifier for a link between the specified region and device/port.
uiLinkId(RegionId, RegionId) - Static method in class org.onosproject.ui.model.topo.UiLinkId
Generates the canonical link identifier for a link between the specified region nodes.
UiLinkId - Class in org.onosproject.ui.model.topo
A canonical representation of an identifier for UiLinks.
UiLinkId.Direction - Enum in org.onosproject.ui.model.topo
Designates the directionality of an underlying (uni-directional) link.
UiLinkId.Type - Enum in org.onosproject.ui.model.topo
Designates the type of link the identifier represents.
UiMessageHandler - Class in org.onosproject.ui
Abstraction of an entity capable of processing JSON messages from the user interface client.
UiMessageHandler() - Constructor for class org.onosproject.ui.UiMessageHandler
 
UiMessageHandlerFactory - Interface in org.onosproject.ui
Abstraction of an entity capable of producing a set of message handlers specific to the given user interface connection.
UiModelEvent - Class in org.onosproject.ui.model.topo
UI Topology model events.
UiModelEvent(UiModelEvent.Type, UiElement, ObjectNode, String) - Constructor for class org.onosproject.ui.model.topo.UiModelEvent
Creates a UI model event.
UiModelEvent.Type - Enum in org.onosproject.ui.model.topo
Enumeration of event types.
UiNode - Class in org.onosproject.ui.model.topo
Represents a node drawn on the topology view (region, device, host).
UiNode() - Constructor for class org.onosproject.ui.model.topo.UiNode
 
UiPreferencesService - Interface in org.onosproject.ui
Service for tracking user interface preferences.
uiRegion() - Method in class org.onosproject.ui.model.topo.UiDevice
Returns the UI region to which this device belongs.
UiRegion - Class in org.onosproject.ui.model.topo
Represents a region.
UiRegion(UiTopology, Region) - Constructor for class org.onosproject.ui.model.topo.UiRegion
Constructs a UI region, with a reference to the specified backing region.
UiRegionDeviceLink - Class in org.onosproject.ui.model.topo
Designates a link between a region node and a device.
UiRegionDeviceLink(UiTopology, UiLinkId) - Constructor for class org.onosproject.ui.model.topo.UiRegionDeviceLink
Creates a region to device UI link.
UiRegionLink - Class in org.onosproject.ui.model.topo
Designates a link between two region nodes.
UiRegionLink(UiTopology, UiLinkId) - Constructor for class org.onosproject.ui.model.topo.UiRegionLink
Creates a region to region UI link.
UiSessionToken - Class in org.onosproject.ui
Encapsulates a session token pertaining to a Web UI websocket connection.
UiSessionToken(String) - Constructor for class org.onosproject.ui.UiSessionToken
Creates a session token from the given string.
UiSynthLink - Class in org.onosproject.ui.model.topo
A synthetic link that encapsulates a UiLink instance and the region to which it belongs.
UiSynthLink(RegionId, UiLink, UiLink) - Constructor for class org.onosproject.ui.model.topo.UiSynthLink
Constructs a synthetic link with the given parameters.
UiTokenService - Interface in org.onosproject.ui
Service for handling UI session tokens.
UiTopo2Overlay - Class in org.onosproject.ui
Represents a user interface topology-2 view overlay.
UiTopo2Overlay(String) - Constructor for class org.onosproject.ui.UiTopo2Overlay
Creates a new user interface topology view overlay descriptor with the given identifier.
UiTopo2OverlayFactory - Interface in org.onosproject.ui
Abstraction of an entity capable of producing one or more topology-2 overlay handlers specific to a given user interface connection.
UiTopoHighlighter - Interface in org.onosproject.ui
Abstraction of an entity capable of generating a set of topology highlights for devices, hosts and links.
UiTopoHighlighterFactory - Interface in org.onosproject.ui
Abstraction of an entity capable of producing a a new topology highlighter.
UiTopoLayout - Class in org.onosproject.ui.model.topo
Represents a specific "subset" of the UI model of the network topology that a user might wish to view.
UiTopoLayout(UiTopoLayoutId) - Constructor for class org.onosproject.ui.model.topo.UiTopoLayout
Created a new UI topology layout.
UiTopoLayoutId - Class in org.onosproject.ui.model.topo
Identifier of a topology layout.
UiTopoLayoutService - Interface in org.onosproject.ui
Service for managing UiTopoLayout instances.
UiTopology - Class in org.onosproject.ui.model.topo
Represents the overall network topology.
UiTopology(ServiceBundle) - Constructor for class org.onosproject.ui.model.topo.UiTopology
Creates a new UI topology backed by the specified service bundle.
UiTopoMap - Class in org.onosproject.ui
Represents a geographically-based map to be used in the user interface topology view.
UiTopoMap(String, String, String, double) - Constructor for class org.onosproject.ui.UiTopoMap
Creates a new topology map.
UiTopoMapFactory - Interface in org.onosproject.ui
Abstraction of an entity capable of producing one or more geographic-based maps for the topology view.
UiTopoOverlay - Class in org.onosproject.ui
Represents user interface topology view overlay.
UiTopoOverlay(String) - Constructor for class org.onosproject.ui.UiTopoOverlay
Creates a new user interface topology view overlay descriptor, with the given identifier.
UiTopoOverlayFactory - Interface in org.onosproject.ui
Abstraction of an entity capable of producing one or more topology overlay handlers specific to a given user interface connection.
uiType() - Method in class org.onosproject.net.config.basics.BasicElementConfig
Returns the UI type (glyph image to be used) for the element in the Topology View.
uiType(String) - Method in class org.onosproject.net.config.basics.BasicElementConfig
Sets the UI type (glyph image to be used) for the element in the Topology View.
UiView - Class in org.onosproject.ui
Represents a user interface view addition.
UiView(UiView.Category, String, String) - Constructor for class org.onosproject.ui.UiView
Creates a new user interface view descriptor.
UiView(UiView.Category, String, String, String) - Constructor for class org.onosproject.ui.UiView
Creates a new user interface view descriptor.
UiView(UiView.Category, String, String, String, String) - Constructor for class org.onosproject.ui.UiView
Creates a new user interface view descriptor.
UiView.Category - Enum in org.onosproject.ui
Designates the navigation menu category.
UiViewHidden - Class in org.onosproject.ui
Represents user interface view addition, except that this one should not have an entry in the navigation panel.
UiViewHidden(String) - Constructor for class org.onosproject.ui.UiViewHidden
Creates a new user interface hidden view descriptor.
UNASSIGNED_40 - org.onosproject.net.flow.criteria.Criterion.Type
Unassigned value: 40.
Unavailable() - Constructor for exception org.onosproject.store.service.StorageException.Unavailable
 
UNAVAILABLE - org.onosproject.store.primitives.PartitionEvent.Type
Signifies that a partition is unavailable for operations.
UnavailableIdException - Exception in org.onosproject.core
Represents that there is no available IDs.
UnavailableIdException() - Constructor for exception org.onosproject.core.UnavailableIdException
Constructs an exception with no message and no underlying cause.
UnavailableIdException(String) - Constructor for exception org.onosproject.core.UnavailableIdException
Constructs an exception with the specified message.
UnavailableIdException(String, Throwable) - Constructor for exception org.onosproject.core.UnavailableIdException
Constructs an exception with the specified message and the underlying cause.
unbindIdGenerator(IdGenerator) - Static method in class org.onosproject.net.intent.Intent
Unbinds an id generator.
UNDERSCORE - Static variable in class org.onosproject.ui.table.cell.AbstractCellFormatter
 
unicast(M, MessageSubject, Function<M, byte[]>, NodeId) - Method in interface org.onosproject.store.cluster.messaging.ClusterCommunicationService
Sends a message to the specified controller node.
UNICAST - org.onlab.packet.DHCP6.OptionCode
 
uninstall(ApplicationId) - Method in interface org.onosproject.app.ApplicationAdminService
Uninstalls the specified application.
union(SparseAnnotations, SparseAnnotations) - Static method in class org.onosproject.net.DefaultAnnotations
Creates the union of two given SparseAnnotations.
unit() - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer
 
unit() - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer
The unit used within this policer.
unit() - Method in class org.onosproject.net.meter.DefaultMeter
 
unit() - Method in class org.onosproject.net.meter.DefaultMeterRequest
 
unit() - Method in interface org.onosproject.net.meter.Meter
The unit used within this meter.
unit() - Method in interface org.onosproject.net.meter.MeterRequest
The unit used within this meter.
unit() - Method in interface org.onosproject.net.pi.model.PiCounterModel
Returns the unit of this counter.
unit() - Method in interface org.onosproject.net.pi.model.PiMeterModel
Returns the unit of this meter.
unitTypes() - Method in class org.onosproject.net.meter.DefaultMeterFeatures
 
unitTypes() - Method in interface org.onosproject.net.meter.MeterFeatures
Returns unit types available for meters.
unixTimestamp() - Method in class org.onosproject.store.service.WallClockTimestamp
Returns the unixTimestamp.
UNKNOWN - org.onlab.packet.EthType.EtherType
 
UNKNOWN - org.onosproject.cluster.ClusterEvent.InstanceType
Signifies that the event refers to an Unknown instance.
UNKNOWN - org.onosproject.net.behaviour.upf.UpfInterface.Type
Unknown UPF interface type.
UNKNOWN - org.onosproject.net.behaviour.upf.UpfProgrammableException.Type
The UpfProgrammable did not provide a specific exception type.
UNKNOWN - org.onosproject.net.flow.FlowEntry.FlowLiveType
Indicates that this rule has been submitted for UNKNOWN or ERROR.
UNKNOWN - org.onosproject.net.flowobjective.ObjectiveError
An unknown error occurred.
UNKNOWN - org.onosproject.net.GridType
 
UNKNOWN - org.onosproject.net.meter.MeterFailReason
The meter that was attempted to be modified is unknown.
UNKNOWN - org.onosproject.net.pi.service.PiPipeconfWatchdogService.PipelineStatus
The status is unknown and the device might not be able to process packets yet.
UNKNOWN - Static variable in class org.onosproject.ui.GlyphConstants
 
UNKNOWN_COMMAND - org.onosproject.net.meter.MeterFailReason
Unknown command.
UNKNOWN_DEVICE - org.onosproject.net.meter.MeterFailReason
The target device is unknown.
UNKNOWN_FLAGS - org.onosproject.net.meter.MeterFailReason
Unknown flags.
UNKNOWN_FLOW - org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Indicates that this rule has been submitted for UNKNOWN or ERROR.
UNKNOWN_GROUP - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
unknownLoad() - Method in class org.onosproject.net.statistic.SummaryFlowEntryWithLoad
Returns unknown load of connect point.
unlock() - Method in class org.onosproject.store.primitives.DefaultDistributedLock
 
unlock() - Method in interface org.onosproject.store.service.AsyncDistributedLock
Unlocks the lock.
unlock() - Method in interface org.onosproject.store.service.DistributedLock
Unlocks the lock.
unmodifiableDeque(Deque<T>) - Static method in class org.onlab.util.UnmodifiableDeque
Returns an unmodifiable view of the specified Deque.
UnmodifiableDeque<E> - Class in org.onlab.util
Unmodifiable view of the specified Deque.
unparsed() - Method in class org.onosproject.net.packet.DefaultInboundPacket
 
unparsed() - Method in interface org.onosproject.net.packet.InboundPacket
Unparsed packet data.
unregister(List<? extends ResourceId>) - Method in interface org.onosproject.net.resource.ResourceAdminService
Unregisters the specified resources.
unregister(List<? extends ResourceId>) - Method in interface org.onosproject.net.resource.ResourceStore
Unregisters the resources in transactional way.
unregister(NodeId) - Method in interface org.onosproject.cluster.LeadershipAdminService
Removes all active leadership registrations for a given node.
unregister(NetworkConfigRegistry) - Static method in class org.onosproject.routing.config.RoutingConfiguration
Unregisters the routing configuration factories.
unregister(PiPipeconfId) - Method in interface org.onosproject.net.pi.service.PiPipeconfService
Unregisters the given pipeconf.
unregister(ResourceId...) - Method in interface org.onosproject.net.resource.ResourceAdminService
Unregisters the specified resources.
unregister(ApiDocProvider) - Method in interface org.onosproject.rest.ApiDocService
Unregisters the specified REST API documentation provider.
unregister(UiExtension) - Method in interface org.onosproject.ui.UiExtensionService
Unregisters the specified user interface extension.
unregister(UiGlyphFactory) - Method in interface org.onosproject.ui.UiExtensionService
Unregisters the specified user interface glyph factory.
unregister(UiTopoHighlighterFactory) - Method in interface org.onosproject.ui.UiExtensionService
Unregisters the specified user interface extension.
unregister(P) - Method in class org.onosproject.net.provider.AbstractProviderRegistry
 
unregister(P) - Method in interface org.onosproject.net.provider.ProviderRegistry
Unregisters the supplied provider.
unregisterCodec(Class<?>) - Method in interface org.onosproject.codec.CodecService
Unregisters the JSON codec for the specified entity class.
unregisterCompiler(Class<T>) - Method in interface org.onosproject.net.intent.IntentExtensionService
Unregisters the compiler for the specified intent class.
unregisterConfigFactory(ConfigFactory) - Method in interface org.onosproject.net.config.NetworkConfigRegistry
Unregisters the specified configuration factory.
unregisterConfigFactory(ConfigFactory) - Method in class org.onosproject.net.config.NetworkConfigRegistryAdapter
 
UNREGISTERED - org.onosproject.net.pi.service.PiPipeconfEvent.Type
 
unregisterHandler(String) - Method in interface org.onosproject.store.cluster.messaging.MessagingService
Unregister current handler, if one exists for message type.
unregisterInstaller(Class<T>) - Method in interface org.onosproject.net.intent.IntentExtensionService
Unregisters the installer for the specific intent class.
unregisterNeighbourHandler(ConnectPoint, NeighbourMessageHandler, ApplicationId) - Method in interface org.onosproject.net.neighbour.NeighbourResolutionService
Unregisters a neighbour message handler that was assigned to a connect point.
unregisterNeighbourHandler(Interface, NeighbourMessageHandler, ApplicationId) - Method in interface org.onosproject.net.neighbour.NeighbourResolutionService
Unregisters a neighbour message handler that was assigned to an interface.
unregisterNeighbourHandlers(ApplicationId) - Method in interface org.onosproject.net.neighbour.NeighbourResolutionService
Unregisters all neighbour handlers that were registered by the given application.
unregisterPortConfigOperator(PortConfigOperator) - Method in interface org.onosproject.net.config.PortConfigOperatorRegistry
Unregisters PortConfigOperator instance.
unregisterProperties(Class<?>, boolean) - Method in interface org.onosproject.cfg.ComponentConfigService
Unregisters configuration properties for the specified component.
unregisterProvider(DriverProvider) - Method in interface org.onosproject.net.driver.DriverAdminService
Unregisters the specified driver provider.
unregisterProxyService(Class<?>) - Method in interface org.onosproject.cluster.ProxyService
Unregisters the proxy service of the given type.
unregisterProxyService(Class<?>) - Method in interface org.onosproject.mastership.MastershipProxyService
Unregisters the proxy service of the given type.
unregisterReporter(MetricsReporter) - Method in class org.onlab.metrics.MetricsManager
Unregisters the given metric reporter.
unregisterReporter(MetricsReporter) - Method in interface org.onlab.metrics.MetricsService
Unregisters the given metric reporter.
UNREP - org.onosproject.cli.net.ExtHeader
Unexpected repeats encountered.
UNREP - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Unexpected repeats encountered.
UNRESOLVED_TYPE - org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
 
UNRESOLVED_TYPE - org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
 
UnresolvedExtensionSelector - Class in org.onosproject.net.flow.criteria
Unresolved extension selector.
UnresolvedExtensionSelector(byte[], ExtensionSelectorType) - Constructor for class org.onosproject.net.flow.criteria.UnresolvedExtensionSelector
Creates a new unresolved extension selector with given data in byte form.
UnresolvedExtensionTreatment - Class in org.onosproject.net.flow.instructions
Unresolved extension treatment.
UnresolvedExtensionTreatment(byte[], ExtensionTreatmentType) - Constructor for class org.onosproject.net.flow.instructions.UnresolvedExtensionTreatment
Creates a new unresolved extension treatment with given data in byte form.
UNSEQ - org.onosproject.cli.net.ExtHeader
Unexpected sequencing encountered.
UNSEQ - org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Unexpected sequencing encountered.
unsetDelegate(D) - Method in class org.onosproject.store.AbstractStore
 
unsetDelegate(D) - Method in interface org.onosproject.store.Store
Withdraws the delegate from the store.
unsetDelegate(TopologyChangeDelegate) - Method in interface org.onosproject.net.intent.ObjectiveTrackerService
Unsets topology change delegate.
unsetProperty(String, String) - Method in interface org.onosproject.cfg.ComponentConfigService
Clears the value of the specified configuration property thus making the property take on its default value.
unsetProperty(String, String) - Method in interface org.onosproject.cfg.ComponentConfigStore
Clears the value of the specified configuration property thus making the property take on its default value.
unsetProperty(String, String) - Method in class org.onosproject.store.cfg.DistributedComponentConfigStore
 
UNSIGNED_BYTE_MASK - Static variable in class org.onlab.packet.dhcp.DhcpOption
 
UNSIGNED_SHORT_MASK - Static variable in class org.onlab.packet.dhcp.Dhcp6Option
 
UNSPECIFIED - org.onosproject.core.ApplicationRole
Indicates that an application role has not been specified.
unsubscribe(Consumer<T>) - Method in interface org.onosproject.store.service.Topic
Unsubscribes from this topic.
UNSUPPORTED - org.onosproject.net.flowobjective.ObjectiveError
The driver processing this objective does not know how to process it.
UNSUPPORTED_OPERATION - org.onosproject.net.behaviour.upf.UpfProgrammableException.Type
The UpfProgrammable implementation doesn't support the operation.
unsuspend(HostId) - Method in interface org.onosproject.net.host.HostStore
Update the host suspended state to false denotes host is in unsuspended state.
UNTAGGED - Static variable in class org.onlab.packet.VlanId
 
UP - Static variable in class org.onosproject.cli.UpDownCompleter
 
update(IntentState) - Method in class org.onosproject.net.intent.util.IntentMiniSummary
Updates the Intent Summary.
UPDATE - org.onosproject.store.service.AtomicValueEvent.Type
Value was updated.
UPDATE - org.onosproject.store.service.MapEvent.Type
Existing map entry updated.
UPDATE_NODE - org.onosproject.store.primitives.NodeUpdate.Type
Updates an entry if the current version matches specified version.
updateAlarmList(DeviceId, Collection<Alarm>) - Method in interface org.onosproject.alarm.AlarmProviderService
Sends active alarm list for a device.
updateAttribute(byte, byte[]) - Method in class org.onlab.packet.RADIUS
Updates an attribute in the RADIUS packet.
updateBandwidthProfile(Collection<BandwidthProfile>) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Updates already configured bandwidth profiles on the device.
updateBandwidthProfile(BandwidthProfile) - Method in interface org.onosproject.net.behaviour.BandwidthProfileConfigBehaviour
Updates an already configured bandwidth profile on the device.
updateBookkeepingFields(AlarmId, boolean, boolean, String) - Method in interface org.onosproject.alarm.AlarmService
Update book-keeping (ie administrative) fields for the alarm matching the specified identifier.
UPDATED - org.onosproject.alarm.AlarmEvent.Type
Individual alarm updated.
UPDATED - org.onosproject.store.primitives.PartitionEvent.Type
Signifies that a partition has been administratively updated.
UPDATED - org.onosproject.store.service.DocumentTreeEvent.Type
Signifies the value of an existing node being updated.
updateFlowStatistic(FlowEntry) - Method in interface org.onosproject.net.statistic.FlowStatisticStore
Updates a stats observation for a flow rule.
updateGroupDescription(DeviceId, GroupKey, GroupStore.UpdateType, GroupBuckets, GroupKey) - Method in interface org.onosproject.net.group.GroupStore
Updates the existing group entry with the information from group description.
updateMeterState(Meter) - Method in interface org.onosproject.net.meter.MeterStore
Updates a given meter's state with the provided state.
updateMetric(String, double) - Method in interface org.onosproject.cpman.MetricsDatabase
Update metric value by specifying metric type.
updateMetric(String, double, long) - Method in interface org.onosproject.cpman.MetricsDatabase
Update metric value by specifying metric type in a certain time.
updateMetric(ControlMetric, int, String) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Adds a new control metric value with a certain update interval.
updateMetric(ControlMetric, int, Optional<DeviceId>) - Method in interface org.onosproject.cpman.ControlPlaneMonitorService
Adds a new control metric value with a certain update interval.
updateMetrics(Map<String, Double>) - Method in interface org.onosproject.cpman.MetricsDatabase
Update metric values of a collection of metric types.
updateMetrics(Map<String, Double>, long) - Method in interface org.onosproject.cpman.MetricsDatabase
Update metric values of a collection of metric types.
updatePorts(DeviceId, List<PortDescription>) - Method in interface org.onosproject.net.device.DeviceProviderService
Updates information about all ports of a device.
updatePorts(ProviderId, DeviceId, List<PortDescription>) - Method in interface org.onosproject.net.device.DeviceStore
Updates the ports of the specified infrastructure device using the given list of port descriptions.
updatePortStatistics(DeviceId, Collection<PortStatistics>) - Method in interface org.onosproject.net.device.DeviceProviderService
Updates statistics about all ports of a device.
updatePortStatistics(ProviderId, DeviceId, Collection<PortStatistics>) - Method in interface org.onosproject.net.device.DeviceStore
Updates the port statistics of the specified device using the give port statistics.
updatePortStatus(ProviderId, DeviceId, PortDescription) - Method in interface org.onosproject.net.device.DeviceStore
Updates the port status of the specified infrastructure device using the given port description.
updateProtectionEndpoint(ConnectPoint, ProtectedTransportEndpointDescription) - Method in interface org.onosproject.net.behaviour.protection.ProtectionConfigBehaviour
Updates protected path endpoint configuration.
updateRegion(RegionId, String, Region.Type, List<Set<NodeId>>) - Method in interface org.onosproject.net.region.RegionAdminService
Update the specified region using the new set of data.
updateRegion(RegionId, String, Region.Type, Annotations, List<Set<NodeId>>) - Method in interface org.onosproject.net.region.RegionStore
Updates the specified new region using the supplied data.
updateStatsInfo(DeviceId, Set<ControlMessage>) - Method in interface org.onosproject.cpman.message.ControlMessageProviderService
Used to notify the core about the control message statistic information.
updateStatsInfo(ProviderId, DeviceId, Set<ControlMessage>) - Method in interface org.onosproject.cpman.message.ControlMessageStore
Updates the control message statistics of the specified device.
updateTableStatistics(DeviceId, List<TableStatisticsEntry>) - Method in interface org.onosproject.net.flow.FlowRuleStore
Updates the flow table statistics of the specified device using the given statistics.
updateTime(String) - Method in class org.onosproject.common.app.ApplicationArchive
Updates the time-stamp of the app descriptor file.
updateTopology(ProviderId, GraphDescription, List<Event>) - Method in interface org.onosproject.net.topology.TopologyStore
Generates a new topology snapshot from the specified description.
UpDownCompleter - Class in org.onosproject.cli
Up/down command completer.
UpDownCompleter() - Constructor for class org.onosproject.cli.UpDownCompleter
 
UpfDevice - Interface in org.onosproject.net.behaviour.upf
Provides means to update forwarding state to implement a 3GPP User Plane Function.
UpfInterface - Class in org.onosproject.net.behaviour.upf
A UPF device interface, such as a S1U or UE IP address pool.
UpfInterface.Builder - Class in org.onosproject.net.behaviour.upf
 
UpfInterface.Type - Enum in org.onosproject.net.behaviour.upf
 
UpfProgrammable - Interface in org.onosproject.net.behaviour.upf
Provides means to update the device forwarding state to implement a 3GPP User Plane Function.
UpfProgrammableException - Exception in org.onosproject.net.behaviour.upf
An exception indicating a an error happened in the UPF programmable behaviour.
UpfProgrammableException(String) - Constructor for exception org.onosproject.net.behaviour.upf.UpfProgrammableException
Creates a new exception for the given message.
UpfProgrammableException(String, UpfProgrammableException.Type) - Constructor for exception org.onosproject.net.behaviour.upf.UpfProgrammableException
Creates a new exception for the given message and type.
UpfProgrammableException.Type - Enum in org.onosproject.net.behaviour.upf
 
upgrade() - Method in interface org.onosproject.net.behaviour.SoftwareUpgrade
Performs an upgrade.
upgrade() - Method in interface org.onosproject.upgrade.UpgradeAdminService
Performs an upgrade, transferring device mastership to upgraded nodes.
Upgrade - Class in org.onosproject.upgrade
Represents the state of an upgrade.
Upgrade(Version, Version, Upgrade.Status) - Constructor for class org.onosproject.upgrade.Upgrade
 
UPGRADE_EVENT - org.onosproject.security.AppPermission.Type
 
UPGRADE_READ - org.onosproject.security.AppPermission.Type
 
UPGRADE_WRITE - org.onosproject.security.AppPermission.Type
 
Upgrade.Status - Enum in org.onosproject.upgrade
Represents the phase of the upgrade protocol.
UpgradeAdminService - Interface in org.onosproject.upgrade
Abstraction for executing the stages of the upgrade process.
upgraded() - Method in enum org.onosproject.upgrade.Upgrade.Status
Returns whether the upgraded version is active.
UPGRADED - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade is complete.
UPGRADED - org.onosproject.upgrade.UpgradeEvent.Type
Indicates that mastership was reassigned to the upgraded cluster.
UpgradeEvent - Class in org.onosproject.upgrade
Upgrade event.
UpgradeEvent(UpgradeEvent.Type, Upgrade) - Constructor for class org.onosproject.upgrade.UpgradeEvent
Creates an event of a given type and for the specified state and the current time.
UpgradeEvent(UpgradeEvent.Type, Upgrade, long) - Constructor for class org.onosproject.upgrade.UpgradeEvent
Creates an event of a given type and for the specified state and time.
UpgradeEvent.Type - Enum in org.onosproject.upgrade
Type of upgrade-related events.
UpgradeEventListener - Interface in org.onosproject.upgrade
Upgrade event listener.
UpgradeService - Interface in org.onosproject.upgrade
Upgrade service.
UPGRADING - org.onosproject.upgrade.Upgrade.Status
Indicates that an upgrade is in progress.
upperBound() - Method in class org.onlab.util.ClosedOpenRange
Returns the upper bound.
UPSTREAM_DROPPED - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Count the dropped packets in the upstream direction.
UPSTREAM_RX - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Count the received packets in the upstream direction.
UPSTREAM_TX - org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Count the transmitted packets in the upstream direction.
URG - org.onosproject.net.flow.criteria.Criterion.TcpFlags
Urgent pointer field is significant.
urgentPointer - Variable in class org.onlab.packet.TCP
 
uri - Variable in class org.onosproject.cli.net.DevicePortsListCommand
 
uri() - Method in class org.onosproject.net.behaviour.trafficcontrol.PolicerId
Returns the backing URI.
uri() - Method in class org.onosproject.net.DeviceId
Returns the backing URI.
URI - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
UriSerializer - Class in org.onosproject.store.serializers
Serializer for URI.
UriSerializer() - Constructor for class org.onosproject.store.serializers.UriSerializer
Creates URI serializer instance.
url() - Method in interface org.onosproject.app.ApplicationDescription
Returns url of the application.
url() - Method in class org.onosproject.app.DefaultApplicationDescription
 
url() - Method in interface org.onosproject.core.Application
Returns url of the application.
url() - Method in class org.onosproject.core.DefaultApplication
 
USE_REGION_FOR_BALANCE_ROLES - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
USE_REGION_FOR_BALANCE_ROLES_DEFAULT - Static variable in class org.onosproject.net.OsgiPropertyConstants
 
useProtectedLink() - Static method in class org.onosproject.net.intent.constraint.ProtectedConstraint
Returns ProtectedConstraint instance.
USER - org.onosproject.core.ApplicationRole
Indicates that an application has a USER role.
USER_CLASS - org.onlab.packet.DHCP6.OptionCode
 
USER_CPU_TIME - org.onosproject.cpman.ControlMetricType
 
userDefinedIndexMode(boolean) - Method in interface org.onosproject.net.meter.MeterStore
Enables/disables user defined index mode for the store.
username() - Method in class org.onosproject.net.key.UsernamePassword
Returns the username.
userName() - Method in interface org.onosproject.ui.UiConnection
Returns the name of the logged-in user for which this connection exists.
USERNAME - Static variable in class org.onosproject.net.AnnotationKeys
Annotation key for the username.
USERNAME_PASSWORD - org.onosproject.net.key.DeviceKey.Type
 
UsernamePassword - Class in org.onosproject.net.key
Representation of a username and password.
using(List<KryoNamespace>, Class<?>...) - Static method in interface org.onosproject.store.service.Serializer
Creates a new Serializer instance from a list of KryoNamespaces and some additional classes.
using(KryoNamespace) - Static method in interface org.onosproject.store.serializers.StoreSerializer
Deprecated.
Creates a new StoreSerializer instance from a KryoNamespace.
using(KryoNamespace) - Static method in interface org.onosproject.store.service.Serializer
Creates a new Serializer instance from a KryoNamespace.
using(KryoNamespace, Class<?>...) - Static method in interface org.onosproject.store.service.Serializer
Creates a new Serializer instance from a KryoNamespace and some additional classes.
UtilityClassChecker - Class in org.onlab.junit
Hamcrest style class for verifying that a class follows the accepted rules for utility classes.
UtilityClassChecker() - Constructor for class org.onlab.junit.UtilityClassChecker
 

V

VALID - org.onosproject.net.intent.constraint.TierConstraint.CostType
Configures the constraint to return the same cost (1.0) for any link that has a valid tier value.
validate(List<Link>) - Static method in class org.onosproject.net.intent.PathIntent
Validates that source element ID and destination element ID of a link are different for the specified all links and that destination element ID of a link and source element ID of the next adjacent source element ID are same for the specified all links.
validate(Path, ResourceContext) - Method in class org.onosproject.net.intent.constraint.BooleanConstraint
 
validate(Path, ResourceContext) - Method in class org.onosproject.net.intent.constraint.LatencyConstraint
 
validate(Path, ResourceContext) - Method in class org.onosproject.net.intent.constraint.MarkerConstraint
 
validate(Path, ResourceContext) - Method in interface org.onosproject.net.intent.Constraint
Validates that the specified path satisfies the constraint.
validate(Path, ResourceContext) - Method in class org.onosproject.net.intent.constraint.WaypointConstraint
 
validateFile(File, File) - Static method in class org.onlab.util.FilePathValidator
Validates a File.
validateZipEntry(ZipEntry, File) - Static method in class org.onlab.util.FilePathValidator
Validates a zip entry.
validChecksum() - Method in class org.onlab.packet.IGMP.IGMPv2
 
validChecksum() - Method in class org.onlab.packet.IGMP.IGMPv3
 
validChecksum() - Method in class org.onlab.packet.IGMP
Validates the message's checksum.
value - Variable in enum org.onlab.packet.DHCP.DHCPOptionCode
 
value - Variable in enum org.onlab.packet.DHCP.MsgType
 
value - Variable in enum org.onlab.packet.DHCP6.MsgType
 
value - Variable in enum org.onlab.packet.DHCP6.OptionCode
 
value - Variable in class org.onlab.packet.LLDPTLV
 
value - Variable in enum org.onlab.packet.PPPoED.Type
 
value - Variable in class org.onlab.packet.PPPoEDTag
 
value - Variable in class org.onlab.packet.RADIUSAttribute
 
value - Variable in enum org.onlab.packet.RIP.CmdType
 
value - Variable in enum org.onlab.packet.RIPng.CmdType
 
value() - Method in class org.onlab.graph.ScalarWeight
Returns inner double value.
value() - Method in class org.onlab.packet.ChassisId
Get the value of the chassis id.
value() - Method in enum org.onlab.packet.DHCP6.MsgType
 
value() - Method in enum org.onlab.packet.DHCP6.OptionCode
 
value() - Method in class org.onosproject.cfg.ComponentConfigEvent
Returns the property value as a string.
value() - Method in class org.onosproject.cfg.ConfigProperty
Returns the property value as a string.
value() - Method in enum org.onosproject.cli.net.EthType
Gets the value to use for this EthType.
value() - Method in enum org.onosproject.cli.net.ExtHeader
Gets the value to use for this ExtHeader.
value() - Method in enum org.onosproject.cli.net.Icmp6Code
Gets the value to use for this Icmp6Code.
value() - Method in enum org.onosproject.cli.net.Icmp6Type
Gets the value to use for this Icmp6Type.
value() - Method in enum org.onosproject.cli.net.IpProtocol
Gets the value to use for this IpProtocol.
value() - Method in class org.onosproject.net.behaviour.TunnelEndPoint
Returns the value.
value() - Method in class org.onosproject.net.behaviour.TunnelKey
Returns the value.
value() - Method in class org.onosproject.net.flow.FlowId
Gets the flow ID value.
value() - Method in class org.onosproject.net.pi.runtime.PiActionParam
Returns the value of this parameter.
value() - Method in class org.onosproject.net.pi.runtime.PiExactFieldMatch
Returns the byte sequence value to be matched.
value() - Method in class org.onosproject.net.pi.runtime.PiLpmFieldMatch
Returns the value matched by this field.
value() - Method in class org.onosproject.net.pi.runtime.PiOptionalFieldMatch
Returns the byte sequence value to be matched.
value() - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata
Returns the value for the field in this metadata.
value() - Method in class org.onosproject.net.pi.runtime.PiTernaryFieldMatch
Returns the value matched by this field.
value() - Method in class org.onosproject.net.resource.ContinuousResource
Returns the value of the resource amount.
value() - Method in class org.onosproject.net.resource.ResourceConsumerId
Returns ID value.
value() - Method in class org.onosproject.store.cluster.messaging.MessageSubject
 
value() - Method in class org.onosproject.store.LogicalTimestamp
Returns the sequence value.
value() - Method in class org.onosproject.store.primitives.MapUpdate
Returns the new value.
value() - Method in class org.onosproject.store.primitives.NodeUpdate
Returns the new value.
value() - Method in interface org.onosproject.store.service.DocumentTreeNode
Returns the value of this node.
value() - Method in class org.onosproject.store.service.EventuallyConsistentMapEvent
Returns the value associated with this event.
value() - Method in class org.onosproject.store.service.Version
Returns the lock version.
value() - Method in class org.onosproject.store.service.Versioned
Returns the value.
value() - Method in class org.onosproject.ui.chart.ChartModel.Annot
Returns the annotation's value.
value() - Method in class org.onosproject.ui.lion.LionBundle.LionItem
Returns the value.
value() - Method in class org.onosproject.ui.table.TableModel.Annot
Returns the annotation's value.
value() - Method in class org.onosproject.ui.topo.PropertyPanel.Prop
Returns the property's value.
value(String) - Method in class org.onosproject.net.AbstractProjectableModel.AnnotationDriverData
 
value(String) - Method in interface org.onosproject.net.Annotations
Returns the value of the specified annotation.
value(String) - Method in class org.onosproject.net.DefaultAnnotations
 
value(String) - Method in class org.onosproject.net.driver.DefaultDriver
 
value(String) - Method in class org.onosproject.net.driver.DefaultDriverData
 
VALUE - org.onosproject.store.service.DistributedPrimitive.Type
Atomic value.
value1() - Method in class org.onosproject.store.service.MultiValuedTimestamp
Returns the first value.
value2() - Method in class org.onosproject.store.service.MultiValuedTimestamp
Returns the second value.
valueAs(Class<T>) - Method in class org.onosproject.net.resource.ContinuousResource
Returns value interpreted as the specified type.
valueAs(Class<T>) - Method in class org.onosproject.net.resource.DiscreteResource
 
valueAs(Class<T>) - Method in interface org.onosproject.net.resource.Resource
Returns value interpreted as the specified type.
valueAsString() - Method in class org.onosproject.ui.chart.ChartModel.Annot
Returns the value as a string.
valueAsString() - Method in class org.onosproject.ui.table.TableModel.Annot
Returns the value as a string.
ValueLabel(long, String) - Constructor for class org.onosproject.ui.topo.TopoUtils.ValueLabel
Creates a value label with the given base value and unit.
valueOf(byte[]) - Static method in class org.onlab.packet.Ip4Address
Converts a byte array into an IPv4 address.
valueOf(byte[]) - Static method in class org.onlab.packet.Ip6Address
Converts a byte array into an IPv6 address.
valueOf(byte[]) - Static method in class org.onlab.packet.MacAddress
Returns a MAC address instance representing the specified byte array.
valueOf(byte[], int) - Static method in class org.onlab.packet.Ip4Address
Converts a byte array and a given offset from the beginning of the array into an IPv4 address.
valueOf(byte[], int) - Static method in class org.onlab.packet.Ip4Prefix
Converts a byte array and a prefix length into an IPv4 prefix.
valueOf(byte[], int) - Static method in class org.onlab.packet.Ip6Address
Converts a byte array and a given offset from the beginning of the array into an IPv6 address.
valueOf(byte[], int) - Static method in class org.onlab.packet.Ip6Prefix
Converts a byte array and a prefix length into an IPv6 prefix.
valueOf(int) - Static method in class org.onlab.packet.Ip4Address
Converts an integer into an IPv4 address.
valueOf(int) - Static method in class org.onlab.packet.IpAddress
Converts an integer into an IPv4 address.
valueOf(int) - Static method in class org.onosproject.core.GroupId
Returns a group ID as an integer value.
valueOf(int, int) - Static method in class org.onlab.packet.Ip4Prefix
Converts an integer and a prefix length into an IPv4 prefix.
valueOf(int, int) - Static method in class org.onlab.packet.IpPrefix
Converts an integer and a prefix length into an IPv4 prefix.
valueOf(long) - Static method in class org.onlab.packet.MacAddress
Returns a MAC address instance representing the specified long value.
valueOf(long) - Static method in class org.onosproject.net.flow.FlowId
Creates a flow ID from a long value.
valueOf(long) - Static method in class org.onosproject.net.intent.IntentId
Creates an intent identifier from the specified long representation.
valueOf(String) - Static method in enum org.onlab.graph.DepthFirstSearch.EdgeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.dhcp.Dhcp6Duid.DuidType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.DHCP.DHCPOptionCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.DHCP.MsgType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.DHCP6.MsgType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.DHCP6.OptionCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.DscpClass
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.EthType.EtherType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.onlab.packet.Ip4Address
Converts an IPv4 string literal (e.g., "10.2.3.4") into an IP address.
valueOf(String) - Static method in class org.onlab.packet.Ip4Prefix
Converts a CIDR (slash) notation string (e.g., "10.1.0.0/16") into an IPv4 prefix.
valueOf(String) - Static method in class org.onlab.packet.Ip6Address
Converts an IPv6 string literal (e.g., "1111:2222::8888") into an IP address.
valueOf(String) - Static method in class org.onlab.packet.Ip6Prefix
Converts a CIDR (slash) notation string (e.g., "1111:2222::/64") into an IPv6 prefix.
valueOf(String) - Static method in class org.onlab.packet.IpAddress
Converts an IPv4 or IPv6 string literal (e.g., "10.2.3.4" or "1111:2222::8888") into an IP address.
valueOf(String) - Static method in enum org.onlab.packet.IpAddress.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.IPPrecedence
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.onlab.packet.IpPrefix
Converts a CIDR (slash) notation string (e.g., "10.1.0.0/16" or "1111:2222::/64") into an IP prefix.
valueOf(String) - Static method in class org.onlab.packet.MacAddress
Returns a MAC address instance representing the value of the specified String.
valueOf(String) - Static method in enum org.onlab.packet.PPPoED.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.RIP.CmdType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.packet.RIPng.CmdType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.util.DataRateUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.util.StringFilter.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onlab.util.Tools.LogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.alarm.Alarm.SeverityLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.alarm.AlarmEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.app.ApplicationEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.app.ApplicationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cfg.ComponentConfigEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cfg.ConfigProperty.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cli.net.EthType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cli.net.ExtHeader
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cli.net.Icmp6Code
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cli.net.Icmp6Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cli.net.IpProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cluster.ClusterEvent.InstanceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cluster.ClusterEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cluster.ClusterMetadataEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cluster.ControllerNode.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cluster.LeadershipEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.core.ApplicationRole
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cpman.ControlMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cpman.ControlMetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cpman.ControlResource.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.cpman.message.ControlMessageEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.dhcp.IpAssignment.AssignmentStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.mastership.MastershipEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.BandwidthProfileAction.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.BngProgrammable.Attachment.AttachmentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.BridgeDescription.FailMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.ControlProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.TelemetrySpec
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable.IntFunctionality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.QosDescription.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.QueueDescription.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.SoftwareUpgrade.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.trafficcontrol.Policer.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.TunnelDescription.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.upf.UpfInterface.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.behaviour.upf.UpfProgrammableException.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.ChannelSpacing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.CltSignalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.config.Config.FieldPresence
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.config.NetworkConfigEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.DataPlaneEntity.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.device.DeviceAgentEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.device.DeviceEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.device.DeviceInterfaceDescription.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.Device.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.domain.DomainIntentOperation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.driver.DriverEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.edge.EdgePortEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.EncapsulationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.criteria.Criterion.TcpFlags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.criteria.Criterion.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.FlowEntry.FlowEntryState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.FlowEntry.FlowLiveType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.FlowRule.FlowRemoveReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.FlowRuleEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.FlowRuleOperation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.Instruction.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.L0ModificationInstruction.L0SubType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.L1ModificationInstruction.L1SubType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.instructions.L4ModificationInstruction.L4SubType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry.FlowRuleOperation
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent.Type
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.StatTriggerField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.StatTriggerFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.TableId.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.FilteringObjective.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.ForwardingObjective.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.NextObjective.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.NextTreatment.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.Objective.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.ObjectiveError
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.flowobjective.ObjectiveEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.GridType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.group.Group.GroupState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.group.GroupDescription.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.group.GroupEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.group.GroupOperation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.group.GroupStore.UpdateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.host.HostEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.host.HostProbingEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.onosproject.net.host.InterfaceIpAddress
Converts a CIDR string literal to an interface IP address.
valueOf(String) - Static method in enum org.onosproject.net.host.ProbeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intent.constraint.TierConstraint.CostType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intent.IntentEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.onosproject.net.intent.IntentId
Creates an intent identifier from the specified String representation.
valueOf(String) - Static method in enum org.onosproject.net.intent.IntentInstaller.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intent.IntentOperation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intent.IntentState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intent.PathIntent.ProtectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intent.WorkPartitionEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.intf.InterfaceEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.key.DeviceKey.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.key.DeviceKeyEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.link.LinkEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.Link.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.Link.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.MastershipRole
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.mcast.McastEvent.Type
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.mcast.McastRoute.Type
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.mcast.McastStore.Type
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.Band.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.Meter.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterCellId.MeterCellType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterFailReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterFeaturesFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterOperation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterRequest.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.meter.MeterStoreResult.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.ModulationScheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.neighbour.NeighbourMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.neighbour.NeighbourProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.OchSignalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.OduSignalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.OtuSignalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.packet.PacketEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.packet.PacketInFilter.FilterAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.packet.PacketPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiCounterModel.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiCounterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiData.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiMatchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiMeterModel.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiMeterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiPacketOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.model.PiTableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.runtime.PiEntityType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.runtime.PiMeterBandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.runtime.PiPreEntryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.runtime.PiTableAction.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.service.PiPipeconfDeviceMappingEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.service.PiPipeconfEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.service.PiPipeconfWatchdogEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.service.PiPipeconfWatchdogService.PipelineStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.pi.service.PiTranslationEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.Port.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.PortNumber.Logical
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.region.Region.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.region.RegionEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.resource.ResourceEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.statistic.PortStatisticsService.MetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.net.topology.TopologyEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.security.AppPermission.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.app.DistributedApplicationStore.InternalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.flow.ReplicaInfoEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.primitives.MapUpdate.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.primitives.NodeUpdate.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.primitives.PartitionEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.AtomicValueEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.CommitStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.DistributedPrimitive.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.DistributedPrimitive.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.DocumentTreeEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.EventuallyConsistentMapEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.MapEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.MultimapEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.Ordering
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.RevisionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.store.service.SetEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.model.topo.UiLinkId.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.model.topo.UiLinkId.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.model.topo.UiModelEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.table.TableModel.SortDir
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.topo.Highlights.Amount
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.topo.LayoutLocation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.topo.LinkHighlight.Flavor
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.topo.NodeBadge.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.topo.TopoElementType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.topo.TopoUtils.Magnitude
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.ui.UiView.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.upgrade.Upgrade.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.onosproject.upgrade.UpgradeEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(InetAddress) - Static method in class org.onlab.packet.Ip4Address
Converts an InetAddress into an IPv4 address.
valueOf(InetAddress) - Static method in class org.onlab.packet.Ip6Address
Converts an InetAddress into an IPv6 address.
valueOf(InetAddress) - Static method in class org.onlab.packet.IpAddress
Converts an InetAddress into an IP address.
valueOf(Ip4Address, int) - Static method in class org.onlab.packet.Ip4Prefix
Converts an IPv4 address and a prefix length into an IPv4 prefix.
valueOf(Ip6Address, int) - Static method in class org.onlab.packet.Ip6Prefix
Converts an IPv6 address and a prefix length into an IPv6 prefix.
valueOf(IpAddress.Version, byte[]) - Static method in class org.onlab.packet.IpAddress
Converts a byte array into an IP address.
valueOf(IpAddress.Version, byte[], int) - Static method in class org.onlab.packet.IpAddress
Converts a byte array and a given offset from the beginning of the array into an IP address.
valueOf(IpAddress.Version, byte[], int) - Static method in class org.onlab.packet.IpPrefix
Converts a byte array and a prefix length into an IP prefix.
valueOf(IpAddress, int) - Static method in class org.onlab.packet.IpPrefix
Converts an IP address and a prefix length into an IP prefix.
valueOrElse(Versioned<U>, U) - Static method in class org.onosproject.store.service.Versioned
Returns the value of the specified Versioned object if non-null or else returns a default value.
valueOrNull(Versioned<U>) - Static method in class org.onosproject.store.service.Versioned
Returns the value of the specified Versioned object if non-null or else returns null.
values() - Static method in enum org.onlab.graph.DepthFirstSearch.EdgeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.dhcp.Dhcp6Duid.DuidType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.DHCP.DHCPOptionCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.DHCP.MsgType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.DHCP6.MsgType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.DHCP6.OptionCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.DscpClass
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.EthType.EtherType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.IpAddress.Version
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.IPPrecedence
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.PPPoED.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.RIP.CmdType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.packet.RIPng.CmdType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.util.DataRateUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.util.StringFilter.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onlab.util.Tools.LogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.alarm.Alarm.SeverityLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.alarm.AlarmEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.app.ApplicationEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.app.ApplicationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cfg.ComponentConfigEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cfg.ConfigProperty.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cli.net.EthType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cli.net.ExtHeader
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cli.net.Icmp6Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cli.net.Icmp6Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cli.net.IpProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cluster.ClusterEvent.InstanceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cluster.ClusterEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cluster.ClusterMetadataEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cluster.ControllerNode.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cluster.LeadershipEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.core.ApplicationRole
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cpman.ControlMessage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cpman.ControlMetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cpman.ControlResource.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.cpman.message.ControlMessageEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.dhcp.IpAssignment.AssignmentStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.mastership.MastershipEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.BandwidthProfileAction.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.BngProgrammable.Attachment.AttachmentType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.BngProgrammable.BngCounterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.BridgeDescription.FailMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.ControlProtocolVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.TelemetrySpec
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.inbandtelemetry.IntMetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.inbandtelemetry.IntProgrammable.IntFunctionality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.QosDescription.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.QueueDescription.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.SoftwareUpgrade.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.trafficcontrol.Policer.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.TunnelDescription.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.upf.UpfInterface.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.behaviour.upf.UpfProgrammableException.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.ChannelSpacing
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.CltSignalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.config.Config.FieldPresence
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.config.NetworkConfigEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.DataPlaneEntity.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.device.DeviceAgentEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.device.DeviceEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.device.DeviceInterfaceDescription.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.Device.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.domain.DomainIntentOperation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.driver.DriverEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.edge.EdgePortEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.EncapsulationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.criteria.Criterion.IPv6ExthdrFlags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.criteria.Criterion.TcpFlags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.criteria.Criterion.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.criteria.ExtensionSelectorType.ExtensionSelectorTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.FlowEntry.FlowEntryState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.FlowEntry.FlowLiveType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.FlowRule.FlowRemoveReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.FlowRuleEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.FlowRuleOperation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.ExtensionTreatmentType.ExtensionTreatmentTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.Instruction.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.L0ModificationInstruction.L0SubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.L1ModificationInstruction.L1SubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.L3ModificationInstruction.L3SubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.instructions.L4ModificationInstruction.L4SubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.oldbatch.FlowRuleBatchEntry.FlowRuleOperation
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.oldbatch.FlowRuleBatchEvent.Type
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.StatTriggerField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.StatTriggerFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.TableId.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flow.TypedStoredFlowEntry.FlowLiveType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.FilteringObjective.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.ForwardingObjective.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.NextObjective.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.NextTreatment.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.Objective.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.ObjectiveError
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.flowobjective.ObjectiveEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.GridType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.group.Group.GroupState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.group.GroupDescription.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.group.GroupEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.group.GroupOperation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.group.GroupStore.UpdateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.host.HostEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.host.HostProbingEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.host.ProbeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.constraint.TierConstraint.CostType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.IntentEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.IntentInstaller.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.IntentOperation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.IntentState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.PathIntent.ProtectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intent.WorkPartitionEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.intf.InterfaceEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.key.DeviceKey.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.key.DeviceKeyEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.link.LinkEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.Link.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.Link.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.MastershipRole
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.mcast.McastEvent.Type
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.mcast.McastRoute.Type
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.mcast.McastStore.Type
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.Band.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.Meter.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterCellId.MeterCellType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterFailReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterFeaturesFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterOperation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterRequest.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.meter.MeterStoreResult.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.ModulationScheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.neighbour.NeighbourMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.neighbour.NeighbourProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.OchSignalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.OduSignalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.OtuSignalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.packet.PacketEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.packet.PacketInFilter.FilterAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.packet.PacketPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiCounterModel.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiCounterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiData.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiMatchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiMeterModel.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiMeterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiPacketOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiPipeconf.ExtensionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.model.PiTableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.runtime.PiEntityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.runtime.PiMeterBandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.runtime.PiPreEntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.runtime.PiTableAction.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.service.PiPipeconfDeviceMappingEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.service.PiPipeconfEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.service.PiPipeconfWatchdogEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.service.PiPipeconfWatchdogService.PipelineStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.pi.service.PiTranslationEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.PipelineTraceableOutput.PipelineTraceableResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.Port.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.PortNumber.Logical
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.region.Region.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.region.RegionEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.resource.ResourceEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.statistic.PortStatisticsService.MetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.net.topology.TopologyEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.security.AppPermission.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.app.DistributedApplicationStore.InternalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.flow.ReplicaInfoEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.onosproject.store.primitives.ConsistentMapBackedJavaMap
 
values() - Method in class org.onosproject.store.primitives.DefaultConsistentMap
 
values() - Method in class org.onosproject.store.primitives.DefaultConsistentMultimap
 
values() - Method in class org.onosproject.store.primitives.DefaultConsistentTreeMap
 
values() - Static method in enum org.onosproject.store.primitives.MapUpdate.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.primitives.NodeUpdate.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.primitives.PartitionEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.onosproject.store.service.AsyncConsistentMap
Returns the collection of values (and associated versions) contained in this map.
values() - Method in interface org.onosproject.store.service.AsyncConsistentMultimap
Returns a collection of values in the set with duplicates permitted, the size of this collection will equal the size of the map at the time of creation.
values() - Static method in enum org.onosproject.store.service.AtomicValueEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.CommitStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.onosproject.store.service.ConsistentMap
Returns the collection of values (and associated versions) contained in this map.
values() - Method in interface org.onosproject.store.service.ConsistentMultimap
Returns a collection of values in the set with duplicates permitted, the size of this collection will equal the size of the map at the time of creation.
values() - Static method in enum org.onosproject.store.service.DistributedPrimitive.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.DistributedPrimitive.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.DocumentTreeEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.onosproject.store.service.EventuallyConsistentMap
Returns a collections of values in this map.
values() - Static method in enum org.onosproject.store.service.EventuallyConsistentMapEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.MapEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.MultimapEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.Ordering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.RevisionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.store.service.SetEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.model.topo.UiLinkId.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.model.topo.UiLinkId.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.model.topo.UiModelEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.table.TableModel.SortDir
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.topo.Highlights.Amount
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.topo.LayoutLocation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.topo.LinkHighlight.Flavor
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.topo.NodeBadge.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.topo.TopoElementType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.topo.TopoUtils.Magnitude
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.ui.UiView.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.upgrade.Upgrade.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.onosproject.upgrade.UpgradeEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
VENDOR - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
VENDOR_CLASS - org.onlab.packet.DHCP6.OptionCode
 
VENDOR_OPTS - org.onlab.packet.DHCP6.OptionCode
 
VENDOR_SPECIFIC - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
verify() - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
verify() - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Builds the next objective that needs to be verified.
verify(ONOSLLDP, String, long) - Static method in class org.onlab.packet.ONOSLLDP
 
verify(ObjectiveContext) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
verify(ObjectiveContext) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Builds the next objective that needs to be verified.
VERIFY - org.onosproject.net.flowobjective.Objective.Operation
Verifies that an existing Next Objective's collection of treatments are correctly represented by the underlying implementation of the objective.
VERIFY - org.onosproject.net.host.ProbeMode
Remove probed host location if reply is received after timeout.
VERSATILE - org.onosproject.net.flowobjective.ForwardingObjective.Flag
A monolithic objective.
version - Variable in class org.onlab.packet.bmp.Bmp
 
version - Variable in class org.onlab.packet.IPv4
 
version - Variable in class org.onlab.packet.IPv6
 
version - Variable in class org.onlab.packet.PIM
 
version - Variable in class org.onlab.packet.PPPoED
 
version - Variable in class org.onlab.packet.RIP
 
version - Variable in class org.onlab.packet.RIPng
 
version() - Method in class org.onlab.packet.IpAddress
Returns the IP version of this address.
version() - Method in class org.onlab.packet.IpPrefix
Returns the IP version of the prefix.
version() - Method in interface org.onosproject.app.ApplicationDescription
Returns the application version.
version() - Method in class org.onosproject.app.DefaultApplicationDescription
 
version() - Method in class org.onosproject.cluster.Member
Returns the node version.
version() - Method in class org.onosproject.cluster.MembershipGroup
Returns the group version.
version() - Method in interface org.onosproject.core.Application
Returns the application version.
version() - Method in interface org.onosproject.core.CoreService
Returns the product version.
version() - Method in class org.onosproject.core.DefaultApplication
 
version() - Method in interface org.onosproject.core.VersionService
Returns the product version.
version() - Method in class org.onosproject.net.intent.IntentData
Returns the request version of the intent for this key.
version() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Returns the primitive version.
version() - Method in class org.onosproject.store.primitives.MapUpdate
Returns the expected current version in the database for the key.
version() - Method in class org.onosproject.store.primitives.NodeUpdate
Returns the expected current version in the database for the key.
version() - Method in class org.onosproject.store.service.TransactionLog
Returns the transaction lock version.
version() - Method in class org.onosproject.store.service.Versioned
Returns the version.
version(int, int, String, String) - Static method in class org.onosproject.core.Version
Creates a new version from the specified constituent numbers.
version(String) - Static method in class org.onosproject.core.Version
Creates a new version by parsing the specified string.
Version - Class in org.onosproject.core
Representation of the product version.
Version - Class in org.onosproject.store.service
Logical timestamp for versions.
Version(long) - Constructor for class org.onosproject.store.service.Version
 
VERSION - org.onosproject.store.service.RevisionType
A distributed primitive that is initialized from the previous revision and sets the previous revision to read-only mode.
VERSION - Static variable in class org.onlab.packet.Ip4Address
 
VERSION - Static variable in class org.onlab.packet.Ip4Prefix
 
VERSION - Static variable in class org.onlab.packet.Ip6Address
 
VERSION - Static variable in class org.onlab.packet.Ip6Prefix
 
VERSION - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
VERSION_MATCH - org.onosproject.store.primitives.MapUpdate.Type
Checks the version of a key without locking the key.
Versioned<V> - Class in org.onosproject.store.service
Versioned value.
Versioned(V, long) - Constructor for class org.onosproject.store.service.Versioned
Constructs a new versioned value.
Versioned(V, long, long) - Constructor for class org.onosproject.store.service.Versioned
Constructs a new versioned value.
versionService - Variable in class org.onosproject.cli.app.ApplicationCommand
 
versionService - Variable in class org.onosproject.store.app.DistributedApplicationStore
 
VersionService - Interface in org.onosproject.core
Node version service.
Vertex - Interface in org.onlab.graph
Representation of a graph vertex.
vertexes() - Method in class org.onosproject.net.topology.DefaultGraphDescription
 
vertexes() - Method in interface org.onosproject.net.topology.GraphDescription
Returns the set of topology graph vertexes.
viewbox() - Method in class org.onosproject.ui.UiGlyph
Returns the viewbox for this glyph.
VIEWBOX - Static variable in class org.onosproject.ui.GlyphConstants
 
views() - Method in class org.onosproject.ui.UiExtension
Returns list of user interface views contributed by this extension.
VIRTUAL - org.onosproject.net.Device.Type
 
VIRTUAL - org.onosproject.net.Link.Type
Signifies that this link is a virtual link or a pseudo-wire.
VIRTUAL - org.onosproject.net.Port.Type
Signifies virtual port.
VIRTUAL_SUBNET_SELECTION - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
VIRTUAL_SUBNET_SELECTION_CTRL - org.onlab.packet.dhcp.DhcpRelayAgentOption.RelayAgentInfoOptions
 
vlan() - Method in class org.onosproject.net.DefaultHost
 
vlan() - Method in class org.onosproject.net.host.DefaultHostDescription
 
vlan() - Method in interface org.onosproject.net.host.HostDescription
Returns the VLAN associated with this host.
vlan() - Method in interface org.onosproject.net.Host
Returns the VLAN ID tied to this host.
vlan() - Method in class org.onosproject.net.intf.Interface
Retrieves the VLAN ID that is assigned to the interface.
vlan() - Method in interface org.onosproject.net.neighbour.NeighbourMessageContext
Gets the vlan of the packet, if any.
vlan() - Method in class org.onosproject.routing.config.BgpConfig.BgpSpeakerConfig
 
VLAN - org.onlab.packet.EthType.EtherType
 
VLAN - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a L2 tunnel.
VLAN - org.onosproject.net.EncapsulationType
Indicates a VLAN encapsulation.
VLAN - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
VLAN - Static variable in class org.onosproject.routing.config.BgpConfig
 
VLAN - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
VLAN_HEADER_LENGTH - Static variable in class org.onlab.packet.Ethernet
 
VLAN_ID - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
VLAN id modification.
VLAN_NATIVE - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
VLAN_NONE - Static variable in class org.onosproject.ui.topo.TopoConstants.Properties
 
VLAN_PCP - org.onosproject.net.flow.criteria.Criterion.Type
VLAN priority.
VLAN_PCP - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
VLAN priority modification.
VLAN_POP - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
VLAN Pop modification.
VLAN_PUSH - org.onosproject.net.flow.instructions.L2ModificationInstruction.L2SubType
VLAN Push modification.
VLAN_TAGGED - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
VLAN_UNTAGGED - Static variable in class org.onlab.packet.Ethernet
 
VLAN_UNTAGGED - Static variable in class org.onosproject.net.config.basics.InterfaceConfig
 
VLAN_VID - org.onosproject.net.flow.criteria.Criterion.Type
VLAN id.
vlanId() - Method in class org.onlab.packet.dhcp.CircuitId
Gets the vlan id of circuit id.
vlanId() - Static method in class org.onlab.packet.VlanId
Creates a VLAN identifier for untagged VLAN.
vlanId() - Method in class org.onosproject.net.flow.criteria.VlanIdCriterion
Gets the VLAN ID to match.
vlanId() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanIdInstruction
 
vlanId() - Method in class org.onosproject.net.HostId
Returns the host vlan Id.
vlanId(short) - Static method in class org.onlab.packet.VlanId
Creates a VLAN identifier using the supplied VLAN identifier.
vlanId(String) - Static method in class org.onlab.packet.VlanId
Creates a VLAN identifier Object using the supplied VLAN identifier.
vlanID - Variable in class org.onlab.packet.Ethernet
 
VlanId - Class in org.onlab.packet
Representation of a VLAN identifier.
VlanIdCriterion - Class in org.onosproject.net.flow.criteria
Implementation of VLAN ID criterion.
vlanNative() - Method in class org.onosproject.net.intf.Interface
Retrieves the VLAN ID that is assigned to untagged packets on this tagged interface.
vlanPcp() - Method in class org.onosproject.net.flow.instructions.L2ModificationInstruction.ModVlanPcpInstruction
 
VlanPcpCriterion - Class in org.onosproject.net.flow.criteria
Implementation of VLAN priority criterion (3 bits).
VlanQuery - Interface in org.onosproject.net.behaviour
A HandlerBehaviour to check the capability of VLAN.
vlans() - Method in class org.onosproject.net.device.DefaultDeviceInterfaceDescription
Returns the VLAN-IDs configured for the interface.
vlans() - Method in interface org.onosproject.net.device.DeviceInterfaceDescription
Returns the VLAN-IDs configured for the interface.
vlanTagged() - Method in class org.onosproject.net.intf.Interface
Retrieves the set of VLAN IDs that are allowed on this interface.
vlanUntagged() - Method in class org.onosproject.net.intf.Interface
Retrieves the VLAN ID that is assigned to untagged packets.
vni - Variable in class org.onlab.packet.VXLAN
 
VXLAN - Class in org.onlab.packet
Representation of a VXLAN(Virtual eXtensible Local Area Network) packet.
VXLAN - org.onosproject.net.behaviour.TunnelDescription.Type
Signifies that this is a DC L2 extension tunnel.
VXLAN() - Constructor for class org.onlab.packet.VXLAN
 
VXLAN_UDP_PORT - Static variable in class org.onlab.packet.UDP
 

W

WAITING_AUDIT_COMPLETE - org.onosproject.net.group.Group.GroupState
Group create request is queued as group AUDIT is in progress.
wallClockTimestamp() - Method in interface org.onosproject.core.HybridLogicalClockService
Returns the current time as a WallClockTimestamp.
WallClockTimestamp - Class in org.onosproject.store.service
A Timestamp that derives its value from the prevailing wallclock time on the controller where it is generated.
WallClockTimestamp() - Constructor for class org.onosproject.store.service.WallClockTimestamp
 
WallClockTimestamp(long) - Constructor for class org.onosproject.store.service.WallClockTimestamp
 
warn(String) - Method in class org.onlab.junit.LoggerAdapter
 
warn(String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
warn(String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
warn(String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
warn(String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
warn(Marker, String) - Method in class org.onlab.junit.LoggerAdapter
 
warn(Marker, String, Object) - Method in class org.onlab.junit.LoggerAdapter
 
warn(Marker, String, Object...) - Method in class org.onlab.junit.LoggerAdapter
 
warn(Marker, String, Object, Object) - Method in class org.onlab.junit.LoggerAdapter
 
warn(Marker, String, Throwable) - Method in class org.onlab.junit.LoggerAdapter
 
WARN - org.onlab.util.Tools.LogLevel
 
WARN - org.onosproject.ui.topo.NodeBadge.Status
 
WARNING - org.onosproject.alarm.Alarm.SeverityLevel
From X.733: This indicates the detection of a potential or impending service affecting fault, before any significant effects have been felt.
WATCH_UNSUPPORTED - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
watchGroup() - Method in class org.onosproject.net.group.DefaultGroupBucket
Returns group identifier used for liveness detection for a failover bucket.
watchGroup() - Method in interface org.onosproject.net.group.GroupBucket
Returns group identifier used for liveness detection for a failover bucket.
watchPort() - Method in class org.onosproject.net.group.DefaultGroupBucket
Returns port number used for liveness detection for a failover bucket.
watchPort() - Method in interface org.onosproject.net.group.GroupBucket
Returns port number used for liveness detection for a failover bucket.
watchSubnets() - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntReportConfig
Gets subnets to be watched.
WaypointConstraint - Class in org.onosproject.net.intent.constraint
Constraint that evaluates elements passed through in order.
WaypointConstraint(DeviceId...) - Constructor for class org.onosproject.net.intent.constraint.WaypointConstraint
Creates a new waypoint constraint.
waypoints() - Method in class org.onosproject.net.intent.constraint.WaypointConstraint
 
WebApplicationExceptionMapper - Class in org.onlab.rest.exceptions
Exception mapper for WebApplicationExceptions.
WebApplicationExceptionMapper() - Constructor for class org.onlab.rest.exceptions.WebApplicationExceptionMapper
 
weight() - Method in class org.onosproject.net.DefaultDisjointPath
 
weight() - Method in class org.onosproject.net.DefaultPath
 
weight() - Method in class org.onosproject.net.flowobjective.DefaultNextTreatment
 
weight() - Method in class org.onosproject.net.flowobjective.IdNextTreatment
 
weight() - Method in interface org.onosproject.net.flowobjective.NextTreatment
weight of this next action.
weight() - Method in class org.onosproject.net.group.DefaultGroupBucket
Returns weight of select group bucket.
weight() - Method in interface org.onosproject.net.group.GroupBucket
Returns weight of select group bucket.
weight() - Method in interface org.onosproject.net.Path
Returns the path cost as an weight instance.
weight() - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
Returns the weight of this group member.
weight() - Method in class org.onosproject.net.pi.runtime.PiActionSet.WeightedAction
 
weight(E) - Method in class org.onlab.graph.DefaultEdgeWeigher
 
weight(E) - Method in interface org.onlab.graph.EdgeWeigher
Returns the weight of the given edge.
weight(TopologyEdge) - Method in class org.onosproject.net.topology.GeoDistanceLinkWeight
 
weight(TopologyEdge) - Method in class org.onosproject.net.topology.HopCountLinkWeigher
 
weight(TopologyEdge) - Method in class org.onosproject.net.topology.MetricLinkWeight
 
Weight - Interface in org.onlab.graph
Abstraction of a graph edge weight.
WEIGHT_UNSUPPORTED - org.onosproject.net.group.GroupOperation.GroupMsgErrorCode
 
WeightedAction(PiAction, int) - Constructor for class org.onosproject.net.pi.runtime.PiActionSet.WeightedAction
Creates a new weighted action instance that can be used in an action set, from the given PI action and weight.
WeightedMember(PiActionProfileMemberId, int) - Constructor for class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
Creates a new reference for the given action profile member ID and weight.
WeightedMember(PiActionProfileMember, int) - Constructor for class org.onosproject.net.pi.runtime.PiActionProfileGroup.WeightedMember
Creates a new reference from the given action profile member instance and weight.
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in class org.onlab.util.BlockingAwareFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in class org.onlab.util.BlockingAwareFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in class org.onlab.util.BlockingAwareFuture
 
WINDOW_BLOCKED - org.onosproject.net.packet.PacketInFilter.FilterAction
Signifies that the current window for packet processing is full and the window is blocked for packet processing.
windowSize - Variable in class org.onlab.packet.TCP
 
wipeDeferred() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
wipeDeferred() - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Instructs the device to clear the deferred instructions set.
WipeOutCommand - Class in org.onosproject.cli.net
Wipes-out the entire network information base, i.e.
WipeOutCommand() - Constructor for class org.onosproject.cli.net.WipeOutCommand
 
withAcknowledged(boolean) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm acknowledged flag.
withAction(TokenBucket.Action) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
 
withAction(TokenBucket.Action) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Builder
Assigns the action to this token bucket.
withAction(PiAction) - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember.Builder
Sets the action of this member.
withAction(PiTableAction) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the action of this table entry.
withActionProfileId(PiActionProfileId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
Sets the ID of the action profile.
withActiveFlowEntries(long) - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
 
withActivePathIndex(int) - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState.Builder
Sets the activePathIndex.
withAnnotations(Annotations) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
withAnnotations(Annotations) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
withAnnotations(Annotations) - Method in interface org.onosproject.net.meter.Meter.Builder
Sets the annotations.
withAnnotations(Annotations) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Sets the annotations.
withAntiEntropyPeriod(long, TimeUnit) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Configures how often to run the anti-entropy background task.
withAppId(ApplicationId) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds an application id.
withApplicationId(ApplicationId) - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Sets the application id that owns this primitive.
withAssignedUser(String) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm assigned user.
withBackgroundExecutor(ScheduledExecutorService) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets the executor to use for background anti-entropy tasks.
withBands(Collection<Band>) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
withBands(Collection<Band>) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
withBands(Collection<Band>) - Method in interface org.onosproject.net.meter.Meter.Builder
Assigns bands to this meter.
withBands(Collection<Band>) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Assigns bands to this meter.
withBandTypes(Set<Band.Type>) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withBandTypes(Set<Band.Type>) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the band types for this meter features.
withBurstSize(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
 
withBurstSize(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Builder
Assigns the burst size to this token bucket.
withCategory(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a category string.
withCategory(String) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a category string.
withCause() - Method in class org.onlab.junit.ExceptionTest
 
withCellId(int) - Method in class org.onosproject.net.behaviour.upf.PdrStats.Builder
Set the Cell ID (index) of the datalane PDR counter that produced this set of stats.
withCellId(MeterCellId) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
withCellId(MeterCellId) - Method in interface org.onosproject.net.meter.Meter.Builder
Assigns the id to this meter cell.
withCellId(PiRegisterCellId) - Method in class org.onosproject.net.pi.runtime.PiRegisterCell.Builder
Sets the register cell identifier for this register.
withClassOfService(int) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry.Builder
Sets the class of service of this clone session.
withCollectorIp(IpAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns a collector IP address to the IntConfig object.
withCollectorNextHopMac(MacAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns a MAC address of the next hop to the collector to the IntConfig object.
withCollectorPort(TpPort) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns a collector UDP port to the IntConfig object.
withCommittedBand(long, long) - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig.Builder
Sets the committed band of this meter.
withCommunicationExecutor(ExecutorService) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets the executor to use for sending events to peers.
withCompatibilityFunction(BiFunction<T, Version, T>) - Method in class org.onosproject.store.service.TopicOptions
Sets a compatibility function on the map.
withCompatibilityFunction(BiFunction<V, Version, V>) - Method in class org.onosproject.store.service.AtomicValueOptions
Sets a compatibility function on the map.
withCompatibilityFunction(BiFunction<V, Version, V>) - Method in class org.onosproject.store.service.ConsistentMapOptions
Sets a compatibility function on the map.
withContext(MeterContext) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
withContext(MeterContext) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Assigns an execution context for this meter request.
withCookie(long) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
withCookie(long) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Assigns a cookie value to this flowrule.
withCookie(long) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the cookie, i.e.
withCounterCellData(PiCounterCellData) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the counter cell data of this table entry.
withCounterId(int) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the dataplane PDR counter cell ID that this PDR is assigned.
withData(ImmutableByteSequence) - Method in class org.onosproject.net.pi.runtime.PiPacketOperation.Builder
Sets the raw packet data.
withData(PiData) - Method in class org.onosproject.net.pi.runtime.PiRegisterCell.Builder
Sets the data of this register cell.
withDescription(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a description string.
withDescription(String) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a description string.
withDescription(String) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
withDescription(String) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns description for this policer.
withDescription(ProtectedTransportEndpointDescription) - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState.Builder
Sets the description.
withDescription(TransportEndpointDescription) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
Sets the description.
withDeviceId(DeviceId) - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
 
withdraw(String) - Method in interface org.onosproject.cluster.LeadershipService
Withdraws from a leadership contest.
withdraw(String) - Method in class org.onosproject.store.primitives.DefaultLeaderElector
 
withdraw(String) - Method in interface org.onosproject.store.service.AsyncLeaderElector
Withdraws from leadership race for a topic.
withdraw(String) - Method in interface org.onosproject.store.service.LeaderElector
Withdraws from leadership race for a topic.
withdraw(Intent) - Static method in class org.onosproject.net.intent.IntentData
Creates IntentData for Intent withdraw request.
withdraw(Intent) - Method in interface org.onosproject.net.intent.IntentService
Withdraws an intent from the system.
withdraw(MeterRequest, MeterCellId) - Method in interface org.onosproject.net.meter.MeterService
Remove a meter from the system and the dataplane.
withdraw(MeterRequest, MeterId) - Method in interface org.onosproject.net.meter.MeterService
Deprecated.
in onos-2.5, replace MeterId with MeterCellId
WITHDRAW - org.onosproject.net.intent.IntentOperation.Type
Indicates that an intent should be removed.
WITHDRAW_REQ - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent will be withdrawn.
WITHDRAW_REQ - org.onosproject.net.intent.IntentState
Indicates that an application has requested that an intent be withdrawn.
WITHDRAWING - org.onosproject.net.intent.IntentState
Indicates that the intent is being withdrawn.
WITHDRAWN - org.onosproject.net.intent.IntentEvent.Type
Signifies that an intent has been withdrawn from the system.
WITHDRAWN - org.onosproject.net.intent.IntentState
Indicates that the intent has been successfully withdrawn.
withDscp(short) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
 
withDscp(short) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Builder
Assigns the dscp value to this token bucket.
withElectionTimeout(long) - Method in class org.onosproject.store.service.LeaderElectorOptions
Sets the election timeout in milliseconds.
withElectionTimeout(long, TimeUnit) - Method in class org.onosproject.store.service.LeaderElectorOptions
Sets the election timeout.
withEnabled(boolean) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription.Builder
Sets enabled state.
withEndIndex(long) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withEndIndex(long) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the end index (inclusive) for this meter features.
withEventExecutor(ExecutorService) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets the executor to use for processing events coming in from peers.
withFasterConvergence() - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Configure anti-entropy to converge faster at the cost of doing more work for each anti-entropy cycle.
withFeatures(List<String>) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a features list.
withFeatures(List<String>) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a features list.
withFeatures(Set<MeterFeaturesFlag>) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withFeatures(Set<MeterFeaturesFlag>) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the features for this meter features for OF1.5.
withFeaturesRepo(URI) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a URI for a features repository.
withFeaturesRepo(Optional<URI>) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a URI for a features repository.
withFlag(ForwardingObjective.Flag) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
withFlag(ForwardingObjective.Flag) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Assigns the flag to the forwarding objective.
withGroupId(int) - Method in class org.onosproject.net.pi.runtime.PiMulticastGroupEntry.Builder
Sets the identifier of this multicast group.
withHardTimeout(int) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
withHardTimeout(int) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets hard timeout parameter in flow table.
withIcon(byte[]) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds an icon.
withIcon(byte[]) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds an icon.
withId(int) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
withId(int) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Specifies the id for this next objective.
withId(TransportEndpointId) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
Sets id.
withId(PolicerId) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
withId(PolicerId) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns the id to this policer.
withId(MeterId) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
withId(MeterId) - Method in interface org.onosproject.net.meter.Meter.Builder
Deprecated.
in Nightingale release (version 1.13.0). Use Meter.Builder.withCellId(MeterCellId) instead.
withId(PiActionId) - Method in class org.onosproject.net.pi.runtime.PiAction.Builder
Sets the identifier of this action.
withId(PiPacketMetadataId) - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata.Builder
Sets the identifier of this packet metadata.
withId(PiPipeconfId) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf.Builder
Sets the identifier of this pipeconf.
withId(PiActionProfileGroupId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
Sets the ID of this action profile group.
withId(PiActionProfileMemberId) - Method in class org.onosproject.net.pi.runtime.PiActionProfileMember.Builder
Sets the identifier of this member.
withIdleTimeout(int) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the idle timeout parameter in flow table.
withImageUrl(URL) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a Binary Image URL.
withIndex(Long) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
withIndex(Long) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Sets the index.
withKey(K) - Method in class org.onosproject.store.primitives.MapUpdate.Builder
 
withKey(Criterion) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
withKey(Criterion) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Specify the key for the filter.
withLive(boolean) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointState.Builder
Sets liveness state.
withLocale(Locale) - Method in class org.onosproject.ui.table.cell.TimeFormatter
Sets the locale to use for formatting the time.
withLocalFarId(int) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the PFCP session-local ID of the far that should apply to packets that this PDR matches.
withManuallyClearable(boolean) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm the manually clearable flag.
withMatchKey(PiMatchKey) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the match key of this table entry.
withMaxBands(short) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withMaxBands(short) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the max bands value for this meter features.
withMaxColors(short) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withMaxColors(short) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the max colors value for this meter features.
withMaxMeters(long) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withMaxMeters(long) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
withMaxPacketLengthBytes(int) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry.Builder
Sets the maximum length in bytes of cloned packets.
withMaxSize(int) - Method in class org.onosproject.net.pi.runtime.PiActionProfileGroup.Builder
Sets the maximum number of members that this group can hold.
withMaxSize(long) - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
 
withMessage() - Method in class org.onlab.junit.ExceptionTest
 
withMeta(TrafficSelector) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
withMeta(TrafficSelector) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
withMeta(TrafficSelector) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Set meta information related to this forwarding objective.
withMeta(TrafficSelector) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Set meta information related to this next objective.
withMeta(TrafficTreatment) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
withMeta(TrafficTreatment) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Set meta information about this filtering condition set.
withMetadata(PiPacketMetadata) - Method in class org.onosproject.net.pi.runtime.PiPacketOperation.Builder
Adds a packet metadata.
withMetadatas(Collection<PiPacketMetadata>) - Method in class org.onosproject.net.pi.runtime.PiPacketOperation.Builder
Adds many packet metadatas.
withMetadataTypes(Set<IntMetadataType>) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective.Builder
Add a metadata type to the IntObjective.
withMeterBand(PiMeterBand) - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig.Builder
Sets a meter band of this meter.
withMeterCellId(PiMeterCellId) - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig.Builder
Sets the meter cell identifier for this meter.
withMetricName(String) - Method in interface org.onosproject.cpman.MetricsDatabase.Builder
Sets the metric name.
withMinFlowHopLatencyChangeNs(int) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Sets the minimal interval of hop latency change for a flow.
withName(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds an application id.
withName(String) - Method in interface org.onosproject.persistence.PersistentMapBuilder
Sets the name of this map.
withName(String) - Method in interface org.onosproject.persistence.PersistentSetBuilder
Sets the name of this set.
withName(String) - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Sets the primitive name.
withName(String) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets the name of the map.
withNullValues() - Method in class org.onosproject.store.service.ConsistentMapOptions
Enables null values in the map.
withOrdering(Ordering) - Method in class org.onosproject.store.service.DocumentTreeOptions
Sets the ordering of the tree nodes.
withOrigin(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds an origin string.
withOrigin(String) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds an origin string.
withoutActionParams() - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule
Return a new instance of this FAR with the action parameters stripped, leaving only the match keys.
withoutActionParams() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule
Return a new instance of this PDR with the action parameters stripped, leaving only the match keys.
withOutput(FilteredConnectPoint) - Method in class org.onosproject.net.behaviour.protection.TransportEndpointDescription.Builder
Sets output configuration.
withPacketsLookedUpCount(long) - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
 
withPacketsMatchedCount(long) - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
 
withParameter(PiActionParam) - Method in class org.onosproject.net.pi.runtime.PiAction.Builder
Adds a runtime parameter.
withParameters(Collection<PiActionParam>) - Method in class org.onosproject.net.pi.runtime.PiAction.Builder
Adds many runtime parameters.
withPath(DocumentPath) - Method in class org.onosproject.store.primitives.NodeUpdate.Builder
 
withPathStates(List<TransportEndpointState>) - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState.Builder
Sets the path states.
withPeakBand(long, long) - Method in class org.onosproject.net.pi.runtime.PiMeterCellConfig.Builder
Sets the peak band of this meter.
withPeerUpdateFunction(BiFunction<K, V, Collection<NodeId>>) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets a function that can determine which peers to replicate updates to.
withPermissions(Set<Permission>) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a permissions set.
withPermissions(Set<Permission>) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a permissions set.
withPersistence() - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Configure the map to persist data to disk.
withPipelineModel(PiPipelineModel) - Method in class org.onosproject.net.pi.model.DefaultPiPipeconf.Builder
Sets the pipeline model of this pipeconf.
withPolicingResource(PolicingResource) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
withPolicingResource(PolicingResource) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns policer id and device id for this policer.
withPortNumber(PortNumber) - Method in class org.onosproject.net.device.DefaultPortDescription.Builder
Sets mandatory field PortNumber.
withPriority(int) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
withPriority(int) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the priority for this flow rule.
withPriority(int) - Method in class org.onosproject.net.flowobjective.DefaultFilteringObjective.Builder
 
withPriority(int) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
withPriority(int) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
Noop.
withPriority(int) - Method in interface org.onosproject.net.flowobjective.FilteringObjective.Builder
Sets the priority for this objective.
withPriority(int) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Sets the priority for this objective.
withPriority(int) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Sets the priority for this objective.
withPriority(int) - Method in interface org.onosproject.net.flowobjective.Objective.Builder
Sets the priority for this objective.
withPriority(int) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the priority of this table entry.
withPurgeOnUninstall() - Method in class org.onosproject.store.service.ConsistentMapOptions
Clears map contents when the owning application is uninstalled.
withPurgeOnUninstall() - Method in class org.onosproject.store.service.ConsistentMultimapOptions
Clears multimap contents when the owning application is uninstalled.
withPurgeOnUninstall() - Method in class org.onosproject.store.service.ConsistentTreeMapOptions
Clears map contents when the owning application is uninstalled.
withPurgeOnUninstall() - Method in class org.onosproject.store.service.DistributedSetOptions
Enables clearing set contents when the owning application is uninstalled.
withPurgeOnUninstall() - Method in class org.onosproject.store.service.DocumentTreeOptions
Clears document tree contents when the owning application is uninstalled.
withQfi(byte) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the QoS Flow Identifier for this PDR.
withQfiMatch() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
The QoS Flow Identifier should be matched to the packet.
withQfiPush() - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
The QoS Flow Identifier should be pushed to the packet.
withRate(long) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
 
withRate(long) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Builder
Assigns the rate to this token bucket.
withRate(long) - Method in interface org.onosproject.net.meter.Band.Builder
Assigns a rate to this band.
withRate(long) - Method in class org.onosproject.net.meter.DefaultBand.Builder
 
withReadme(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a readme string.
withReadme(String) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a readme string.
withReason(FlowRule.FlowRemoveReason) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
withReason(FlowRule.FlowRemoveReason) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets reason parameter received from switches .
withRelaxedReadConsistency() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Turns on relaxed consistency for read operations.
withRequiredApps(List<String>) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a list of required applications.
withRequiredApps(List<String>) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a list of required applications.
withResourceName(String) - Method in interface org.onosproject.cpman.MetricsDatabase.Builder
Sets the resource name.
withRevisionType(RevisionType) - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Sets the primitive revision type.
withRole(ApplicationRole) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds an application role.
withRole(ApplicationRole) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds an application role.
withScope(MeterScope) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withScope(MeterScope) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
withScope(MeterScope) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the meter scope.
withScope(MeterScope) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Sets the scope.
withSelector(TrafficSelector) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntObjective.Builder
Assigns a selector to the IntObjective.
withSelector(TrafficSelector) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
withSelector(TrafficSelector) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the selector (or match field) for this flow rule.
withSelector(TrafficSelector) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
withSelector(TrafficSelector) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Assigns a selector to the forwarding objective.
withSerializer(KryoNamespace) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets a serializer that can be used to create a serializer that can serialize both the keys and values put into the map.
withSerializer(KryoNamespace.Builder) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets a serializer builder that can be used to create a serializer that can serialize both the keys and values put into the map.
withSerializer(Serializer) - Method in interface org.onosproject.persistence.PersistentMapBuilder
Sets the key serializer to be used to serialize this map, this is a required parameter.
withSerializer(Serializer) - Method in interface org.onosproject.persistence.PersistentSetBuilder
Sets the serializer to be used to serialize this set, this is a required parameter.
withSerializer(Serializer) - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Sets the serializer to use for transcoding info held in the primitive.
withServiceAffecting(boolean) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm service affecting flag.
withSessionId(int) - Method in class org.onosproject.net.pi.runtime.PiCloneSessionEntry.Builder
Sets the identifier of this clone session.
withSessionId(long) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set the ID of the PFCP session that created this FAR.
withSessionId(long) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the ID of the PFCP session that produced this PDR.
withSessionId(ImmutableByteSequence) - Method in class org.onosproject.net.behaviour.upf.ForwardingActionRule.Builder
Set the ID of the PFCP session that created this FAR.
withSessionId(ImmutableByteSequence) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the ID of the PFCP session that produced this PDR.
withSinkIp(IpAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns an IP address of the sink device to the IntConfig object.
withSinkMac(MacAddress) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns a MAC address of the sink device to the IntConfig object.
withStartIndex(long) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withStartIndex(long) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the start index (inclusive) for this meter features.
withTableId(TableId) - Method in class org.onosproject.net.flow.DefaultTableStatisticsEntry.Builder
 
withTeid(int) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the identifier of the GTP tunnel that this PDR matches on.
withTeid(ImmutableByteSequence) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the identifier of the GTP tunnel that this PDR matches on.
withTelemetrySpec(IntDeviceConfig.TelemetrySpec) - Method in class org.onosproject.net.behaviour.inbandtelemetry.IntDeviceConfig.Builder
Assigns the type of telemetry spec to the IntConfig object.
withTimeCleared(Long) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm time cleared.
withTimeout(double) - Method in class org.onosproject.net.pi.runtime.PiTableEntry.Builder
Sets the timeout of this table entry.
withTimestampProvider(BiFunction<K, V, Timestamp>) - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Sets the function to use for generating timestamps for map updates.
withTimeUpdated(long) - Method in class org.onosproject.alarm.DefaultAlarm.Builder
Sets the new alarm time updated.
withTitle(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a title string.
withTitle(String) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a title string.
withTokenBuckets(Collection<TokenBucket>) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
withTokenBuckets(Collection<TokenBucket>) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns token buckets for this policer.
withTombstonesDisabled() - Method in interface org.onosproject.store.service.EventuallyConsistentMapBuilder
Prevents this map from writing tombstones of items that have been removed.
withTotalCompleted(long) - Method in class org.onosproject.store.service.WorkQueueStats.Builder
 
withTotalInProgress(long) - Method in class org.onosproject.store.service.WorkQueueStats.Builder
 
withTotalPending(long) - Method in class org.onosproject.store.service.WorkQueueStats.Builder
 
withTreatment(TrafficTreatment) - Method in class org.onosproject.net.flow.DefaultFlowRule.Builder
 
withTreatment(TrafficTreatment) - Method in interface org.onosproject.net.flow.FlowRule.Builder
Sets the traffic treatment for this flow rule.
withTreatment(TrafficTreatment) - Method in class org.onosproject.net.flowobjective.DefaultForwardingObjective.Builder
 
withTreatment(TrafficTreatment) - Method in interface org.onosproject.net.flowobjective.ForwardingObjective.Builder
Assigns the treatment for this forwarding objective.
withTunnel(ImmutableByteSequence, Ip4Address) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the tunnel ID and destination IP of the GTP tunnel that this PDR matches on.
withTunnel(ImmutableByteSequence, Ip4Address, byte) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the tunnel ID, destination IP and QFI of the GTP tunnel that this PDR matches on.
withTunnelDst(Ip4Address) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the destination IP of the GTP tunnel that this PDR matches on.
withType(TokenBucket.Type) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultTokenBucket.Builder
 
withType(TokenBucket.Type) - Method in interface org.onosproject.net.behaviour.trafficcontrol.TokenBucket.Builder
Assigns the type to this token bucket.
withType(NextObjective.Type) - Method in class org.onosproject.net.flowobjective.DefaultNextObjective.Builder
 
withType(NextObjective.Type) - Method in interface org.onosproject.net.flowobjective.NextObjective.Builder
Sets the type of next step.
withType(PiPacketOperationType) - Method in class org.onosproject.net.pi.runtime.PiPacketOperation.Builder
Sets the type of this packet.
withType(MapUpdate.Type) - Method in class org.onosproject.store.primitives.MapUpdate.Builder
 
withType(NodeUpdate.Type) - Method in class org.onosproject.store.primitives.NodeUpdate.Builder
 
withUeAddr(Ip4Address) - Method in class org.onosproject.net.behaviour.upf.PacketDetectionRule.Builder
Set the UE IP address that this PDR matches on.
withUnit(Policer.Unit) - Method in class org.onosproject.net.behaviour.trafficcontrol.DefaultPolicer.Builder
 
withUnit(Policer.Unit) - Method in interface org.onosproject.net.behaviour.trafficcontrol.Policer.Builder
Assigns the unit to use for this policer.
withUnit(Meter.Unit) - Method in class org.onosproject.net.meter.DefaultMeter.Builder
 
withUnit(Meter.Unit) - Method in class org.onosproject.net.meter.DefaultMeterRequest.Builder
 
withUnit(Meter.Unit) - Method in interface org.onosproject.net.meter.Meter.Builder
Assigns the @See Unit to use for this meter.
withUnit(Meter.Unit) - Method in interface org.onosproject.net.meter.MeterRequest.Builder
Assigns the @See Unit to use for this meter.
withUnits(Set<Meter.Unit>) - Method in class org.onosproject.net.meter.DefaultMeterFeatures.Builder
 
withUnits(Set<Meter.Unit>) - Method in interface org.onosproject.net.meter.MeterFeatures.Builder
Assigns the capabilities for this meter features.
withUpdatesDisabled() - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Disables state changing operations on the returned distributed primitive.
withUrl(String) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a URL string.
withUrl(String) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a URL string.
withValue(ImmutableByteSequence) - Method in class org.onosproject.net.pi.runtime.PiPacketMetadata.Builder
Sets the value of this metadata.
withValue(V) - Method in class org.onosproject.store.primitives.MapUpdate.Builder
 
withValue(V) - Method in class org.onosproject.store.primitives.NodeUpdate.Builder
 
withVersion(long) - Method in class org.onosproject.store.primitives.MapUpdate.Builder
 
withVersion(long) - Method in class org.onosproject.store.primitives.NodeUpdate.Builder
 
withVersion(Version) - Method in class org.onosproject.app.DefaultApplicationDescription.Builder
Adds a version string.
withVersion(Version) - Method in class org.onosproject.core.DefaultApplication.Builder
Adds a version string.
withVersion(Version) - Method in class org.onosproject.store.primitives.DistributedPrimitiveOptions
Sets the primitive version.
withZone(ZoneId) - Method in class org.onosproject.ui.table.cell.TimeFormatter
Sets the time zone to use for formatting the time.
WORK_QUEUE - org.onosproject.store.service.DistributedPrimitive.Type
Distributed work queue.
workingPathIndex() - Method in class org.onosproject.net.behaviour.protection.ProtectedTransportEndpointState
WorkPartitionEvent - Class in org.onosproject.net.intent
Partition event.
WorkPartitionEvent(WorkPartitionEvent.Type, String) - Constructor for class org.onosproject.net.intent.WorkPartitionEvent
 
WorkPartitionEvent.Type - Enum in org.onosproject.net.intent
 
WorkPartitionEventListener - Interface in org.onosproject.net.intent
Entity capable of receiving device partition-related events.
WorkPartitionService - Interface in org.onosproject.net.intent
Service for partitioning work, represented via a unique identifier, onto cluster nodes.
WorkQueue<E> - Interface in org.onosproject.store.service
Distributed Work Queue primitive.
workQueueBuilder() - Method in interface org.onosproject.store.service.PrimitiveService
Creates a new WorkQueueBuilder.
WorkQueueBuilder<E> - Class in org.onosproject.store.service
Builder for WorkQueue.
WorkQueueBuilder() - Constructor for class org.onosproject.store.service.WorkQueueBuilder
 
WorkQueueOptions<O extends WorkQueueOptions<O,​E>,​E> - Class in org.onosproject.store.service
Builder for WorkQueue.
WorkQueueOptions() - Constructor for class org.onosproject.store.service.WorkQueueOptions
 
WorkQueueStats - Class in org.onosproject.store.service
Statistics for a WorkQueue.
WorkQueueStats.Builder - Class in org.onosproject.store.service
 
wrap(byte[]) - Method in interface org.onlab.packet.EAPOLMkpduDistributedSAKParameterSet.KeyWrapper
 
wrap(Runnable) - Static method in class org.onlab.util.SafeRecurringTask
Wraps a runnable in a safe recurring task.
write(Kryo, Output, ImmutableList<?>) - Method in class org.onosproject.store.serializers.ImmutableListSerializer
 
write(Kryo, Output, ImmutableMap<?, ?>) - Method in class org.onosproject.store.serializers.ImmutableMapSerializer
 
write(Kryo, Output, ImmutableSet<?>) - Method in class org.onosproject.store.serializers.ImmutableSetSerializer
 
write(Kryo, Output, URI) - Method in class org.onosproject.store.serializers.UriSerializer
 
write(Kryo, Output, BitSet) - Method in class org.onosproject.store.serializers.BitSetSerializer
 
write(Kryo, Output, List<?>) - Method in class org.onosproject.store.serializers.ArraysAsListSerializer
 
write(Kryo, Output, Ip4Address) - Method in class org.onosproject.store.serializers.Ip4AddressSerializer
 
write(Kryo, Output, Ip4Prefix) - Method in class org.onosproject.store.serializers.Ip4PrefixSerializer
 
write(Kryo, Output, Ip6Address) - Method in class org.onosproject.store.serializers.Ip6AddressSerializer
 
write(Kryo, Output, Ip6Prefix) - Method in class org.onosproject.store.serializers.Ip6PrefixSerializer
 
write(Kryo, Output, IpAddress) - Method in class org.onosproject.store.serializers.IpAddressSerializer
 
write(Kryo, Output, IpPrefix) - Method in class org.onosproject.store.serializers.IpPrefixSerializer
 
write(Kryo, Output, MacAddress) - Method in class org.onosproject.store.serializers.MacAddressSerializer
 
write(Kryo, Output, ImmutableByteSequence) - Method in class org.onosproject.store.serializers.ImmutableByteSequenceSerializer
 
write(Kryo, Output, NodeId) - Method in class org.onosproject.store.serializers.NodeIdSerializer
 
write(Kryo, Output, DefaultApplicationId) - Method in class org.onosproject.store.serializers.DefaultApplicationIdSerializer
 
write(Kryo, Output, MastershipTerm) - Method in class org.onosproject.store.serializers.MastershipTermSerializer
 
write(Kryo, Output, ConnectPoint) - Method in class org.onosproject.store.serializers.ConnectPointSerializer
 
write(Kryo, Output, DefaultAnnotations) - Method in class org.onosproject.store.serializers.AnnotationsSerializer
 
write(Kryo, Output, DefaultLink) - Method in class org.onosproject.store.serializers.DefaultLinkSerializer
 
write(Kryo, Output, DefaultPort) - Method in class org.onosproject.store.serializers.DefaultPortSerializer
 
write(Kryo, Output, DeviceId) - Method in class org.onosproject.store.serializers.DeviceIdSerializer
 
write(Kryo, Output, FilteredConnectPoint) - Method in class org.onosproject.store.serializers.FilteredConnectPointSerializer
 
write(Kryo, Output, ExtensionCriterion) - Method in class org.onosproject.store.serializers.ExtensionCriterionSerializer
 
write(Kryo, Output, Instructions.ExtensionInstructionWrapper) - Method in class org.onosproject.store.serializers.ExtensionInstructionSerializer
 
write(Kryo, Output, HostLocation) - Method in class org.onosproject.store.serializers.HostLocationSerializer
 
write(Kryo, Output, LinkKey) - Method in class org.onosproject.store.serializers.LinkKeySerializer
 
write(Kryo, Output, DefaultOutboundPacket) - Method in class org.onosproject.store.serializers.DefaultOutboundPacketSerializer
 
write(Kryo, Output, PortNumber) - Method in class org.onosproject.store.serializers.PortNumberSerializer
 
write(Kryo, Output, ProviderId) - Method in class org.onosproject.store.serializers.ProviderIdSerializer
 
write(Kryo, Output, MastershipBasedTimestamp) - Method in class org.onosproject.store.serializers.custom.MastershipBasedTimestampSerializer
 
write(IntentData) - Method in interface org.onosproject.net.intent.IntentStore
Writes an IntentData object to the store.
writeMetadata() - Method in class org.onosproject.net.flow.DefaultTrafficTreatment
 
writeMetadata() - Method in interface org.onosproject.net.flow.TrafficTreatment
Returns the metadata instruction if there is one.
writeMetadata(long, long) - Method in class org.onosproject.net.flow.DefaultTrafficTreatment.Builder
 
writeMetadata(long, long) - Static method in class org.onosproject.net.flow.instructions.Instructions
Writes metadata to associate with a packet.
writeMetadata(long, long) - Method in interface org.onosproject.net.flow.TrafficTreatment.Builder
Writes metadata to associate with a packet.
writeRandomFile(File, int, int) - Static method in class org.onlab.junit.TestTools
Writes random binary content into the specified file.
writeRegisterCell(PiRegisterCell) - Method in interface org.onosproject.net.behaviour.PiRegisterProgrammable
Write a register cell of this device.
writeString(String, ByteBuffer, int) - Method in class org.onlab.packet.DHCP
 
writeTo(ObjectNode, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class org.onlab.rest.JsonBodyWriter
 

X

X_MARK - Static variable in class org.onosproject.ui.GlyphConstants
 
XmlDriverLoader - Class in org.onosproject.net.driver
Utility capable of reading driver configuration XML resources and producing a device driver provider as a result.
XmlDriverLoader(ClassLoader, BehaviourClassResolver) - Constructor for class org.onosproject.net.driver.XmlDriverLoader
Creates a new driver loader capable of loading drivers from the supplied class loader.
XmlEventParser - Class in org.onosproject.alarm
Parser for Netconf notifications.
XmlString - Class in org.onlab.util
PrettyPrinted XML String.

Y

yellowAction() - Method in class org.onosproject.net.behaviour.BandwidthProfile
Obtains the action to be taken for traffic marked as yellow.
yellowAction(BandwidthProfileAction) - Method in class org.onosproject.net.behaviour.BandwidthProfile.Builder
Sets the yellow action of this builder.
yield(T) - Method in class org.onlab.util.Generator
Makes available the next item.
yourIPAddress - Variable in class org.onlab.packet.DHCP
 

Z

ZERO - org.onosproject.ui.topo.Highlights.Amount
 
ZERO - Static variable in class org.onlab.packet.Ip4Address
All-zero unspecified IPv4 address.
ZERO - Static variable in class org.onlab.packet.Ip6Address
All-zero unspecified IPv6 address.
ZERO - Static variable in class org.onlab.packet.MacAddress
All-zero MAC address.
ZERO_THRESHOLD - Static variable in class org.onosproject.net.config.basics.BasicElementConfig
Threshold for detecting double value is zero.
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